2025.09.09 14:47:29.379312 [ 409 ] {} Context: ThreadFuzzer is enabled. Application will run slowly and unstable. 2025.09.09 14:47:29.380570 [ 409 ] {} Context: Server was built with address sanitizer. It will work slowly. 2025.09.09 14:47:29.756713 [ 409 ] {} Context: Delay accounting is not enabled, OSIOWaitMicroseconds will not be gathered. You can enable it using `echo 1 > /proc/sys/kernel/task_delayacct` or by using sysctl. 2025.09.09 14:47:29.760873 [ 409 ] {} Context: The setting 'allow_remote_fs_zero_copy_replication' is enabled for MergeTree tables. But the feature of 'zero-copy replication' is under development and is not ready for production. The usage of this feature can lead to data corruption and loss. The setting should be disabled in production. 2025.09.09 14:47:33.950849 [ 409 ] {} KeeperLogStore: No logs exists in /var/lib/clickhouse/coordination/logs. It's Ok if it's the first run of clickhouse-keeper. 2025.09.09 14:47:33.954409 [ 409 ] {} KeeperLogStore: Removing all changelogs 2025.09.09 14:47:33.960943 [ 409 ] {} KeeperServer: Got 1000000000000000 value for setting 'reserved_log_items' which is bigger than int32_t max value, lowering value to 2147483647. 2025.09.09 14:47:33.972665 [ 409 ] {} RaftInstance: invalid election timeout lower bound detected, adjusted to 0 2025.09.09 14:47:33.973157 [ 409 ] {} RaftInstance: invalid election timeout upper bound detected, adjusted to 0 2025.09.09 14:47:34.030564 [ 1024 ] {} RaftInstance: Election timeout, initiate leader election 2025.09.09 14:47:35.006618 [ 409 ] {} Access(local_directory): File /var/lib/clickhouse/access/users.list doesn't exist 2025.09.09 14:47:35.007381 [ 409 ] {} Access(local_directory): Recovering lists in directory /var/lib/clickhouse/access/ 2025.09.09 14:47:35.763338 [ 409 ] {} Context: Table system.session_log is enabled. It's unreliable and may contain garbage. Do not use it for any kind of security monitoring. 2025.09.09 14:47:38.818696 [ 412 ] {81c55e7f-6fdf-4e4f-aa3e-b1cb8b28c9b2} InterpreterCreateQuery: ATTACH TABLE query with full table definition is not recommended: use either ATTACH TABLE hits_v1; to attach existing table or CREATE TABLE hits_v1 ; to create new table or ATTACH TABLE hits_v1 FROM '/path/to/data/'
; to create new table and attach data. 2025.09.09 14:47:52.190765 [ 412 ] {7bd58eb1-79c1-4e48-967b-46e791585bbb} InterpreterCreateQuery: ATTACH TABLE query with full table definition is not recommended: use either ATTACH TABLE visits_v1; to attach existing table or CREATE TABLE visits_v1
; to create new table or ATTACH TABLE visits_v1 FROM '/path/to/data/'
; to create new table and attach data. 2025.09.09 14:48:04.606101 [ 1025 ] {} RaftInstance: failed to accept a rpc connection due to error 125, Operation canceled 2025.09.09 14:48:09.815537 [ 1276 ] {} Context: ThreadFuzzer is enabled. Application will run slowly and unstable. 2025.09.09 14:48:09.816553 [ 1276 ] {} Context: Server was built with address sanitizer. It will work slowly. 2025.09.09 14:48:10.382028 [ 1276 ] {} Context: Delay accounting is not enabled, OSIOWaitMicroseconds will not be gathered. You can enable it using `echo 1 > /proc/sys/kernel/task_delayacct` or by using sysctl. 2025.09.09 14:48:10.390303 [ 1276 ] {} Context: The setting 'allow_remote_fs_zero_copy_replication' is enabled for MergeTree tables. But the feature of 'zero-copy replication' is under development and is not ready for production. The usage of this feature can lead to data corruption and loss. The setting should be disabled in production. 2025.09.09 14:48:13.743161 [ 1276 ] {} KeeperServer: Got 1000000000000000 value for setting 'reserved_log_items' which is bigger than int32_t max value, lowering value to 2147483647. 2025.09.09 14:48:13.932906 [ 1276 ] {} RaftInstance: invalid election timeout lower bound detected, adjusted to 0 2025.09.09 14:48:13.933545 [ 1276 ] {} RaftInstance: invalid election timeout upper bound detected, adjusted to 0 2025.09.09 14:48:13.991195 [ 1885 ] {} RaftInstance: Election timeout, initiate leader election 2025.09.09 14:48:21.299990 [ 1276 ] {} Context: Table system.session_log is enabled. It's unreliable and may contain garbage. Do not use it for any kind of security monitoring. 2025.09.09 14:49:09.387303 [ 1279 ] {ff9b64d6-3f7c-466e-9b1f-deaa83f0bd4e} executeQuery: Code: 241. DB::Exception: Memory limit (for user) exceeded: would use 9.18 GiB (attempt to allocate chunk of 1114112 bytes), maximum: 9.18 GiB. OvercommitTracker decision: Query was selected to stop by OvercommitTracker.: (avg_value_size_hint = 17.214141845703125, avg_chars_size = 11.05697021484375, limit = 8192): (while reading column SearchPhrase): (while reading from part store/78e/78ebf6a1-d987-4579-b3ec-00c1a087b1f3/201403_1_1_2/ in table datasets.hits_v1 (78ebf6a1-d987-4579-b3ec-00c1a087b1f3) located on disk __tmp_internal_262634248876485800814430204900764312493 of type web, from mark 20 with max_rows_to_read = 8192): While executing MergeTreeSelect(pool: ReadPool, algorithm: Thread). (MEMORY_LIMIT_EXCEEDED) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:52120) (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, long&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001adfc65d 4. ./build_docker/./src/Common/MemoryTracker.cpp:343: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001adfaddf 5. ./build_docker/./src/Common/MemoryTracker.cpp:0: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001adfa777 6. ./build_docker/./src/Common/MemoryTracker.cpp:0: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001adfa777 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:59: CurrentMemoryTracker::alloc(long) @ 0x000000001ad3289d 8. ./build_docker/./src/Common/Allocator.cpp:151: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001ad2eb85 9. ./src/Common/PODArray.h:120: DB::SerializationString::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x0000000027c0e979 10. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:0: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x0000000027aa00db 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:196: DB::MergeTreeReaderWide::readData(DB::NameAndTypePair const&, std::shared_ptr const&, COW::immutable_ptr&, unsigned long, bool, unsigned long, unsigned long, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map, std::hash, std::equal_to, std::allocator>>>&, bool) @ 0x000000002c80211e 12. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:158: DB::MergeTreeReaderWide::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c800e8d 13. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:118: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7c9d8a 14. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x000000002c7e0473 15. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x000000002c7dbec3 16. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:0: DB::MergeTreeReadTask::read(DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002c82d05b 17. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:38: DB::MergeTreeThreadSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&, DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002de66094 18. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:0: DB::MergeTreeSelectProcessor::read() @ 0x000000002c8242f9 19. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000002de6d77a 20. ./build_docker/./src/Processors/ISource.cpp:0: DB::ISource::work() @ 0x000000002d3290a1 21. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 23. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:381: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000002d34bd35 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7eaf0 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001af8a79f 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 28. asan_thread_start(void*) @ 0x000000000aa43059 29. ? @ 0x00007f5bdc8d4ac3 30. ? @ 0x00007f5bdc966850 2025.09.09 14:49:18.946667 [ 1279 ] {ff9b64d6-3f7c-466e-9b1f-deaa83f0bd4e} TCPHandler: Code: 241. DB::Exception: Memory limit (for user) exceeded: would use 9.18 GiB (attempt to allocate chunk of 1114112 bytes), maximum: 9.18 GiB. OvercommitTracker decision: Query was selected to stop by OvercommitTracker.: (avg_value_size_hint = 17.214141845703125, avg_chars_size = 11.05697021484375, limit = 8192): (while reading column SearchPhrase): (while reading from part store/78e/78ebf6a1-d987-4579-b3ec-00c1a087b1f3/201403_1_1_2/ in table datasets.hits_v1 (78ebf6a1-d987-4579-b3ec-00c1a087b1f3) located on disk __tmp_internal_262634248876485800814430204900764312493 of type web, from mark 20 with max_rows_to_read = 8192): While executing MergeTreeSelect(pool: ReadPool, algorithm: Thread). (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, long&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001adfc65d 4. ./build_docker/./src/Common/MemoryTracker.cpp:343: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001adfaddf 5. ./build_docker/./src/Common/MemoryTracker.cpp:0: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001adfa777 6. ./build_docker/./src/Common/MemoryTracker.cpp:0: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001adfa777 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:59: CurrentMemoryTracker::alloc(long) @ 0x000000001ad3289d 8. ./build_docker/./src/Common/Allocator.cpp:151: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001ad2eb85 9. ./src/Common/PODArray.h:120: DB::SerializationString::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x0000000027c0e979 10. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:0: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x0000000027aa00db 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:196: DB::MergeTreeReaderWide::readData(DB::NameAndTypePair const&, std::shared_ptr const&, COW::immutable_ptr&, unsigned long, bool, unsigned long, unsigned long, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map, std::hash, std::equal_to, std::allocator>>>&, bool) @ 0x000000002c80211e 12. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:158: DB::MergeTreeReaderWide::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c800e8d 13. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:118: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7c9d8a 14. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x000000002c7e0473 15. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x000000002c7dbec3 16. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:0: DB::MergeTreeReadTask::read(DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002c82d05b 17. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:38: DB::MergeTreeThreadSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&, DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002de66094 18. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:0: DB::MergeTreeSelectProcessor::read() @ 0x000000002c8242f9 19. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000002de6d77a 20. ./build_docker/./src/Processors/ISource.cpp:0: DB::ISource::work() @ 0x000000002d3290a1 21. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 23. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:381: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000002d34bd35 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7eaf0 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001af8a79f 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 28. asan_thread_start(void*) @ 0x000000000aa43059 29. ? @ 0x00007f5bdc8d4ac3 30. ? @ 0x00007f5bdc966850 2025.09.09 14:49:44.872888 [ 1279 ] {ccc3a172-5842-4374-90c9-2b40f76c3852} executeQuery: Code: 241. DB::Exception: Memory limit (for user) exceeded: would use 9.18 GiB (attempt to allocate chunk of 1064960 bytes), maximum: 9.18 GiB. OvercommitTracker decision: Query was selected to stop by OvercommitTracker.: (while reading column YCLID): (while reading from part store/78e/78ebf6a1-d987-4579-b3ec-00c1a087b1f3/201403_1_1_2/ in table datasets.hits_v1 (78ebf6a1-d987-4579-b3ec-00c1a087b1f3) located on disk __tmp_internal_262634248876485800814430204900764312493 of type web, from mark 88 with max_rows_to_read = 8192): While executing MergeTreeSelect(pool: ReadPool, algorithm: Thread). (MEMORY_LIMIT_EXCEEDED) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:51688) (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, long&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001adfc65d 4. ./build_docker/./src/Common/MemoryTracker.cpp:343: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001adfaddf 5. ./build_docker/./src/Common/MemoryTracker.cpp:0: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001adfa777 6. ./build_docker/./src/Common/MemoryTracker.cpp:0: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001adfa777 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:59: CurrentMemoryTracker::alloc(long) @ 0x000000001ad3289d 8. ./build_docker/./src/Common/Allocator.cpp:151: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001ad2eb85 9. void DB::PODArrayBase<8ul, 4096ul, Allocator, 63ul, 64ul>::resize<>(unsigned long) @ 0x000000000aa93cd0 10. ./src/Common/PODArray.h:315: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x0000000027b976e6 11. ./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 @ 0x0000000027aa00db 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:196: DB::MergeTreeReaderWide::readData(DB::NameAndTypePair const&, std::shared_ptr const&, COW::immutable_ptr&, unsigned long, bool, unsigned long, unsigned long, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map, std::hash, std::equal_to, std::allocator>>>&, bool) @ 0x000000002c80211e 13. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:158: DB::MergeTreeReaderWide::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c800e8d 14. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:118: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7c9d8a 15. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x000000002c7e0473 16. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x000000002c7dbec3 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:0: DB::MergeTreeReadTask::read(DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002c82d05b 18. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:38: DB::MergeTreeThreadSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&, DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002de66094 19. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:0: DB::MergeTreeSelectProcessor::read() @ 0x000000002c8242f9 20. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000002de6d77a 21. ./build_docker/./src/Processors/ISource.cpp:0: DB::ISource::work() @ 0x000000002d3290a1 22. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 23. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:381: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000002d34bd35 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7eaf0 26. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001af8a79f 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 29. asan_thread_start(void*) @ 0x000000000aa43059 30. ? @ 0x00007f5bdc8d4ac3 31. ? @ 0x00007f5bdc966850 2025.09.09 14:49:48.840135 [ 1918 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {8dd55f4d-4394-4634-a445-9c7c9e0f4148::202509_1_14_3}: Code: 241. DB::Exception: Memory tracker (for thread): fault injected (at specific point). (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, char const*&&) @ 0x000000001adfc17a 4. ./build_docker/./src/Common/MemoryTracker.cpp:187: MemoryTracker::injectFault() const @ 0x000000001adf8d1a 5. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:0: DB::MergePlainMergeTreeTask::finish() @ 0x000000002cc30a65 6. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:0: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000002cc2f47b 7. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000002c427f28 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000002c429675 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7eaf0 10. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001af8a79f 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 13. asan_thread_start(void*) @ 0x000000000aa43059 14. ? @ 0x00007f5bdc8d4ac3 15. ? @ 0x00007f5bdc966850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:49:52.619450 [ 1279 ] {ccc3a172-5842-4374-90c9-2b40f76c3852} TCPHandler: Code: 241. DB::Exception: Memory limit (for user) exceeded: would use 9.18 GiB (attempt to allocate chunk of 1064960 bytes), maximum: 9.18 GiB. OvercommitTracker decision: Query was selected to stop by OvercommitTracker.: (while reading column YCLID): (while reading from part store/78e/78ebf6a1-d987-4579-b3ec-00c1a087b1f3/201403_1_1_2/ in table datasets.hits_v1 (78ebf6a1-d987-4579-b3ec-00c1a087b1f3) located on disk __tmp_internal_262634248876485800814430204900764312493 of type web, from mark 88 with max_rows_to_read = 8192): While executing MergeTreeSelect(pool: ReadPool, algorithm: Thread). (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, long&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001adfc65d 4. ./build_docker/./src/Common/MemoryTracker.cpp:343: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001adfaddf 5. ./build_docker/./src/Common/MemoryTracker.cpp:0: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001adfa777 6. ./build_docker/./src/Common/MemoryTracker.cpp:0: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001adfa777 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:59: CurrentMemoryTracker::alloc(long) @ 0x000000001ad3289d 8. ./build_docker/./src/Common/Allocator.cpp:151: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001ad2eb85 9. void DB::PODArrayBase<8ul, 4096ul, Allocator, 63ul, 64ul>::resize<>(unsigned long) @ 0x000000000aa93cd0 10. ./src/Common/PODArray.h:315: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x0000000027b976e6 11. ./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 @ 0x0000000027aa00db 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:196: DB::MergeTreeReaderWide::readData(DB::NameAndTypePair const&, std::shared_ptr const&, COW::immutable_ptr&, unsigned long, bool, unsigned long, unsigned long, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map, std::hash, std::equal_to, std::allocator>>>&, bool) @ 0x000000002c80211e 13. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:158: DB::MergeTreeReaderWide::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c800e8d 14. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:118: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7c9d8a 15. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x000000002c7e0473 16. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x000000002c7dbec3 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:0: DB::MergeTreeReadTask::read(DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002c82d05b 18. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:38: DB::MergeTreeThreadSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&, DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002de66094 19. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:0: DB::MergeTreeSelectProcessor::read() @ 0x000000002c8242f9 20. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000002de6d77a 21. ./build_docker/./src/Processors/ISource.cpp:0: DB::ISource::work() @ 0x000000002d3290a1 22. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 23. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:381: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000002d34bd35 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7eaf0 26. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001af8a79f 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 29. asan_thread_start(void*) @ 0x000000000aa43059 30. ? @ 0x00007f5bdc8d4ac3 31. ? @ 0x00007f5bdc966850 2025.09.09 14:50:38.137344 [ 1886 ] {} RaftInstance: failed to accept a rpc connection due to error 125, Operation canceled 2025.09.09 14:50:40.818277 [ 2683 ] {} Context: ThreadFuzzer is enabled. Application will run slowly and unstable. 2025.09.09 14:50:40.819476 [ 2683 ] {} Context: Server was built with address sanitizer. It will work slowly. 2025.09.09 14:50:41.309667 [ 2683 ] {} Context: Server logging level is set to 'test' and performance is degraded. This cannot be used in production. 2025.09.09 14:50:41.311586 [ 2683 ] {} Context: Delay accounting is not enabled, OSIOWaitMicroseconds will not be gathered. You can enable it using `echo 1 > /proc/sys/kernel/task_delayacct` or by using sysctl. 2025.09.09 14:50:41.320801 [ 2683 ] {} Context: The setting 'allow_remote_fs_zero_copy_replication' is enabled for MergeTree tables. But the feature of 'zero-copy replication' is under development and is not ready for production. The usage of this feature can lead to data corruption and loss. The setting should be disabled in production. 2025.09.09 14:50:46.173351 [ 2683 ] {} KeeperServer: Got 1000000000000000 value for setting 'reserved_log_items' which is bigger than int32_t max value, lowering value to 2147483647. 2025.09.09 14:50:46.197666 [ 2683 ] {} RaftInstance: invalid election timeout lower bound detected, adjusted to 0 2025.09.09 14:50:46.198383 [ 2683 ] {} RaftInstance: invalid election timeout upper bound detected, adjusted to 0 2025.09.09 14:50:46.258579 [ 3303 ] {} RaftInstance: Election timeout, initiate leader election 2025.09.09 14:50:54.185817 [ 2683 ] {} Context: Table system.session_log is enabled. It's unreliable and may contain garbage. Do not use it for any kind of security monitoring. 2025.09.09 14:50:56.113540 [ 2686 ] {c33df526-a11f-4bb2-82b2-6f988d8bd4ce} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=1, jobs=1). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:48834) (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af80b71 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80746 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d34b5ca 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000002d3486e4 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000002d34827b 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002d36bcf7 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 12. asan_thread_start(void*) @ 0x000000000aa43059 13. ? @ 0x00007f35aab92ac3 14. ? @ 0x00007f35aac24850 2025.09.09 14:50:56.115434 [ 2686 ] {c33df526-a11f-4bb2-82b2-6f988d8bd4ce} 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af80b71 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80746 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d34b5ca 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000002d3486e4 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000002d34827b 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002d36bcf7 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 12. asan_thread_start(void*) @ 0x000000000aa43059 13. ? @ 0x00007f35aab92ac3 14. ? @ 0x00007f35aac24850 2025.09.09 14:51:01.441718 [ 2686 ] {ae612b03-a6f2-4b37-9b81-ff4606b25043} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=715, jobs=704). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:58524) (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af872f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af7b2d1 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af7c3f3 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d36920d 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000002d369e5f 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processOrdinaryQuery() @ 0x000000002d18af7b 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d17644a 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 15. asan_thread_start(void*) @ 0x000000000aa43059 16. ? @ 0x00007f35aab92ac3 17. ? @ 0x00007f35aac24850 2025.09.09 14:51:01.446056 [ 2686 ] {ae612b03-a6f2-4b37-9b81-ff4606b25043} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=715, jobs=704). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af872f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af7b2d1 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af7c3f3 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d36920d 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000002d369e5f 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processOrdinaryQuery() @ 0x000000002d18af7b 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d17644a 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 15. asan_thread_start(void*) @ 0x000000000aa43059 16. ? @ 0x00007f35aab92ac3 17. ? @ 0x00007f35aac24850 2025.09.09 14:51:07.498907 [ 2688 ] {3c783905-14a4-4419-bd00-55ded4ce20e8} 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.10505.altinitytest (altinity build)) (from [::1]:37646) (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af819ed 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80746 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d34b5ca 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:306: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349fbb 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:381: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000002d34bd35 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7eaf0 10. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001af8a79f 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 13. asan_thread_start(void*) @ 0x000000000aa43059 14. ? @ 0x00007f35aab92ac3 15. ? @ 0x00007f35aac24850 2025.09.09 14:51:07.501356 [ 2688 ] {3c783905-14a4-4419-bd00-55ded4ce20e8} DynamicQueryHandler: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=9, jobs=9). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af819ed 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80746 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d34b5ca 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:306: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349fbb 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:381: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000002d34bd35 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7eaf0 10. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001af8a79f 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 13. asan_thread_start(void*) @ 0x000000000aa43059 14. ? @ 0x00007f35aab92ac3 15. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:51:08.444132 [ 3604 ] {370c9863-a2e9-4a9b-9a2b-0677df98572d} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=2, jobs=2). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:36552) (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af80b71 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80746 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d34b5ca 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000002d3486e4 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000002d34827b 9. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:113: DB::CompletedPipelineExecutor::execute() @ 0x000000002d34579e 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1635: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000029b40110 11. ./build_docker/./src/Server/HTTPHandler.cpp:529: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000002d0662d1 12. ./build_docker/./src/Server/HTTPHandler.cpp:705: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000002d06d139 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000002d1cc337 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 18. asan_thread_start(void*) @ 0x000000000aa43059 19. ? @ 0x00007f35aab92ac3 20. ? @ 0x00007f35aac24850 2025.09.09 14:51:08.446441 [ 3604 ] {370c9863-a2e9-4a9b-9a2b-0677df98572d} DynamicQueryHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=2, jobs=2). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af80b71 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80746 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d34b5ca 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000002d3486e4 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000002d34827b 9. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:113: DB::CompletedPipelineExecutor::execute() @ 0x000000002d34579e 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1635: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000029b40110 11. ./build_docker/./src/Server/HTTPHandler.cpp:529: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000002d0662d1 12. ./build_docker/./src/Server/HTTPHandler.cpp:705: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000002d06d139 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000002d1cc337 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 18. asan_thread_start(void*) @ 0x000000000aa43059 19. ? @ 0x00007f35aab92ac3 20. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:51:10.633156 [ 3612 ] {955954ca-c30c-464d-9e14-34f42c63ab87} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=6, jobs=6). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:36770) (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af80b71 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80746 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d34b5ca 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000002d3486e4 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000002d34827b 9. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:113: DB::CompletedPipelineExecutor::execute() @ 0x000000002d34579e 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1635: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000029b40110 11. ./build_docker/./src/Server/HTTPHandler.cpp:529: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000002d0662d1 12. ./build_docker/./src/Server/HTTPHandler.cpp:705: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000002d06d139 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000002d1cc337 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 18. asan_thread_start(void*) @ 0x000000000aa43059 19. ? @ 0x00007f35aab92ac3 20. ? @ 0x00007f35aac24850 2025.09.09 14:51:10.641250 [ 3612 ] {955954ca-c30c-464d-9e14-34f42c63ab87} DynamicQueryHandler: 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af80b71 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80746 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d34b5ca 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000002d3486e4 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000002d34827b 9. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:113: DB::CompletedPipelineExecutor::execute() @ 0x000000002d34579e 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1635: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000029b40110 11. ./build_docker/./src/Server/HTTPHandler.cpp:529: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000002d0662d1 12. ./build_docker/./src/Server/HTTPHandler.cpp:705: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000002d06d139 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000002d1cc337 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 18. asan_thread_start(void*) @ 0x000000000aa43059 19. ? @ 0x00007f35aab92ac3 20. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:51:11.362649 [ 2688 ] {726e2246-0c19-4e28-b855-9511f905dc19} 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.10505.altinitytest (altinity build)) (from [::1]:36842) (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af819ed 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80746 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d34b5ca 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000002d3486e4 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000002d34827b 9. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:113: DB::CompletedPipelineExecutor::execute() @ 0x000000002d34579e 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1635: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000029b40110 11. ./build_docker/./src/Server/HTTPHandler.cpp:529: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000002d0662d1 12. ./build_docker/./src/Server/HTTPHandler.cpp:705: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000002d06d139 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000002d1cc337 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 18. asan_thread_start(void*) @ 0x000000000aa43059 19. ? @ 0x00007f35aab92ac3 20. ? @ 0x00007f35aac24850 2025.09.09 14:51:11.371229 [ 2688 ] {726e2246-0c19-4e28-b855-9511f905dc19} DynamicQueryHandler: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=1, jobs=1). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af819ed 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80746 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d34b5ca 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000002d3486e4 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000002d34827b 9. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:113: DB::CompletedPipelineExecutor::execute() @ 0x000000002d34579e 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1635: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000029b40110 11. ./build_docker/./src/Server/HTTPHandler.cpp:529: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000002d0662d1 12. ./build_docker/./src/Server/HTTPHandler.cpp:705: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000002d06d139 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000002d1cc337 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 18. asan_thread_start(void*) @ 0x000000000aa43059 19. ? @ 0x00007f35aab92ac3 20. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:51:11.666443 [ 3612 ] {72ecf643-48ea-4a98-87c3-b0b12b856cfd} 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.10505.altinitytest (altinity build)) (from [::1]:36910) (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af819ed 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80746 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d34b5ca 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000002d3486e4 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000002d34827b 9. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:113: DB::CompletedPipelineExecutor::execute() @ 0x000000002d34579e 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1635: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000029b40110 11. ./build_docker/./src/Server/HTTPHandler.cpp:529: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000002d0662d1 12. ./build_docker/./src/Server/HTTPHandler.cpp:705: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000002d06d139 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000002d1cc337 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 18. asan_thread_start(void*) @ 0x000000000aa43059 19. ? @ 0x00007f35aab92ac3 20. ? @ 0x00007f35aac24850 2025.09.09 14:51:11.674513 [ 3612 ] {72ecf643-48ea-4a98-87c3-b0b12b856cfd} DynamicQueryHandler: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=1, jobs=1). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af819ed 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80746 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d34b5ca 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000002d3486e4 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000002d34827b 9. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:113: DB::CompletedPipelineExecutor::execute() @ 0x000000002d34579e 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1635: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000029b40110 11. ./build_docker/./src/Server/HTTPHandler.cpp:529: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000002d0662d1 12. ./build_docker/./src/Server/HTTPHandler.cpp:705: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000002d06d139 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000002d1cc337 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 18. asan_thread_start(void*) @ 0x000000000aa43059 19. ? @ 0x00007f35aab92ac3 20. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:51:12.638868 [ 3604 ] {62bab94a-0ad6-4e1a-92a1-2ce887036678} 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.10505.altinitytest (altinity build)) (from [::1]:36980) (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af819ed 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80746 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d34b5ca 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000002d3486e4 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000002d34827b 9. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:113: DB::CompletedPipelineExecutor::execute() @ 0x000000002d34579e 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1635: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000029b40110 11. ./build_docker/./src/Server/HTTPHandler.cpp:529: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000002d0662d1 12. ./build_docker/./src/Server/HTTPHandler.cpp:705: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000002d06d139 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000002d1cc337 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 18. asan_thread_start(void*) @ 0x000000000aa43059 19. ? @ 0x00007f35aab92ac3 20. ? @ 0x00007f35aac24850 2025.09.09 14:51:12.642379 [ 3604 ] {62bab94a-0ad6-4e1a-92a1-2ce887036678} DynamicQueryHandler: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=0, jobs=0). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af819ed 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80746 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d34b5ca 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000002d3486e4 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000002d34827b 9. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:113: DB::CompletedPipelineExecutor::execute() @ 0x000000002d34579e 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1635: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000029b40110 11. ./build_docker/./src/Server/HTTPHandler.cpp:529: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000002d0662d1 12. ./build_docker/./src/Server/HTTPHandler.cpp:705: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000002d06d139 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000002d1cc337 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 18. asan_thread_start(void*) @ 0x000000000aa43059 19. ? @ 0x00007f35aab92ac3 20. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:51:13.113654 [ 3651 ] {56e13f2a-43d1-45ee-9b9c-42f43aedadf3} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=4, jobs=4). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:37010) (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af80b71 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80746 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d34b5ca 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:306: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349fbb 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:381: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000002d34bd35 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7eaf0 10. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001af8a79f 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 13. asan_thread_start(void*) @ 0x000000000aa43059 14. ? @ 0x00007f35aab92ac3 15. ? @ 0x00007f35aac24850 2025.09.09 14:51:13.125251 [ 3651 ] {56e13f2a-43d1-45ee-9b9c-42f43aedadf3} DynamicQueryHandler: 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af80b71 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80746 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d34b5ca 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:306: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349fbb 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:381: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000002d34bd35 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7eaf0 10. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001af8a79f 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 13. asan_thread_start(void*) @ 0x000000000aa43059 14. ? @ 0x00007f35aab92ac3 15. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:51:14.158404 [ 2688 ] {00ee686e-dc75-4b44-b7d9-b0ab3f496823} 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.10505.altinitytest (altinity build)) (from [::1]:37074) (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af819ed 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80746 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d34b5ca 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000002d3486e4 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000002d34827b 9. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:113: DB::CompletedPipelineExecutor::execute() @ 0x000000002d34579e 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1635: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000029b40110 11. ./build_docker/./src/Server/HTTPHandler.cpp:529: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000002d0662d1 12. ./build_docker/./src/Server/HTTPHandler.cpp:705: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000002d06d139 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000002d1cc337 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 18. asan_thread_start(void*) @ 0x000000000aa43059 19. ? @ 0x00007f35aab92ac3 20. ? @ 0x00007f35aac24850 2025.09.09 14:51:14.172968 [ 2688 ] {00ee686e-dc75-4b44-b7d9-b0ab3f496823} DynamicQueryHandler: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=9, jobs=9). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af819ed 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80746 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d34b5ca 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000002d3486e4 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000002d34827b 9. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:113: DB::CompletedPipelineExecutor::execute() @ 0x000000002d34579e 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1635: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000029b40110 11. ./build_docker/./src/Server/HTTPHandler.cpp:529: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000002d0662d1 12. ./build_docker/./src/Server/HTTPHandler.cpp:705: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000002d06d139 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000002d1cc337 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 18. asan_thread_start(void*) @ 0x000000000aa43059 19. ? @ 0x00007f35aab92ac3 20. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:51:14.586540 [ 3604 ] {b65f5838-9e1d-4f45-86b6-6425b650884b} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=5, jobs=5). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:37114) (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af80b71 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80746 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d34b5ca 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000002d3486e4 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000002d34827b 9. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:113: DB::CompletedPipelineExecutor::execute() @ 0x000000002d34579e 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1635: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000029b40110 11. ./build_docker/./src/Server/HTTPHandler.cpp:529: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000002d0662d1 12. ./build_docker/./src/Server/HTTPHandler.cpp:705: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000002d06d139 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000002d1cc337 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 18. asan_thread_start(void*) @ 0x000000000aa43059 19. ? @ 0x00007f35aab92ac3 20. ? @ 0x00007f35aac24850 2025.09.09 14:51:14.599145 [ 3604 ] {b65f5838-9e1d-4f45-86b6-6425b650884b} DynamicQueryHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=5, jobs=5). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af80b71 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80746 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d34b5ca 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000002d3486e4 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000002d34827b 9. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:113: DB::CompletedPipelineExecutor::execute() @ 0x000000002d34579e 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1635: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000029b40110 11. ./build_docker/./src/Server/HTTPHandler.cpp:529: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000002d0662d1 12. ./build_docker/./src/Server/HTTPHandler.cpp:705: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000002d06d139 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000002d1cc337 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 18. asan_thread_start(void*) @ 0x000000000aa43059 19. ? @ 0x00007f35aab92ac3 20. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:51:14.615488 [ 3640 ] {4b22a330-1078-4ded-ae23-5615de8406f0} executeQuery: Code: 47. DB::Exception: Unknown expression or function identifier 'Sign' in scope SELECT CounterID % 100000 AS CounterID, sum(Sign) AS visits FROM test.visits GROUP BY CounterID HAVING visits > 0. (UNKNOWN_IDENTIFIER) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:56834) (comment: 00074_full_join.sql) (in query: SELECT CounterID, hits, visits FROM ( SELECT (CounterID % 100000) AS CounterID, count() AS hits FROM test.hits GROUP BY CounterID ) ANY RIGHT JOIN ( SELECT (CounterID % 100000) AS CounterID, sum(Sign) AS visits FROM test.visits GROUP BY CounterID HAVING visits > 0 ) USING CounterID WHERE hits = 0 OR visits = 0 ORDER BY hits + visits * 10 DESC, CounterID ASC LIMIT 20;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String const&, String&&, String&&) @ 0x00000000283c6735 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3684: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002836a1d4 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028366290 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2813: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000028391dce 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000028367bce 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028366290 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283b62c9 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002835ae03 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3783: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000283679cf 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5153: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000283ba3b9 13. ./contrib/llvm-project/libcxx/include/vector:1491: DB::QueryAnalyzer::resolveJoin(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000283bdaec 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000283ba42e 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002835ad09 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000028359104 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000028357f0d 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002921bdcc 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&) @ 0x000000002941f313 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&) @ 0x0000000029419aef 21. ./contrib/llvm-project/libcxx/include/vector:432: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000029421f5d 22. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000029344c1b 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*) @ 0x0000000029b3703b 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 25. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 26. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 30. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 31. asan_thread_start(void*) @ 0x000000000aa43059 2025.09.09 14:51:14.641177 [ 3640 ] {4b22a330-1078-4ded-ae23-5615de8406f0} TCPHandler: Code: 47. DB::Exception: Unknown expression or function identifier 'Sign' in scope SELECT CounterID % 100000 AS CounterID, sum(Sign) AS visits FROM test.visits GROUP BY CounterID HAVING visits > 0. (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String const&, String&&, String&&) @ 0x00000000283c6735 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3684: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002836a1d4 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028366290 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2813: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000028391dce 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000028367bce 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028366290 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283b62c9 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002835ae03 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3783: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000283679cf 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5153: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000283ba3b9 13. ./contrib/llvm-project/libcxx/include/vector:1491: DB::QueryAnalyzer::resolveJoin(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000283bdaec 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000283ba42e 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002835ad09 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000028359104 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000028357f0d 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002921bdcc 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&) @ 0x000000002941f313 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&) @ 0x0000000029419aef 21. ./contrib/llvm-project/libcxx/include/vector:432: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000029421f5d 22. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000029344c1b 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*) @ 0x0000000029b3703b 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 25. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 26. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 30. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 31. asan_thread_start(void*) @ 0x000000000aa43059 2025.09.09 14:51:16.560745 [ 2688 ] {36b75687-e003-4b43-b82e-d2e2b6f93e6d} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=1, jobs=1). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:56862) (comment: 00036_aggregate_hashed.sql) (in query: SELECT SearchEngineID AS k1, SearchPhrase AS k2, count() AS c FROM test.hits GROUP BY k1, k2 ORDER BY c DESC, k1, k2 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af80b71 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80746 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d34b5ca 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000002d3486e4 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000002d34827b 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002d36bcf7 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 12. asan_thread_start(void*) @ 0x000000000aa43059 13. ? @ 0x00007f35aab92ac3 14. ? @ 0x00007f35aac24850 2025.09.09 14:51:16.570501 [ 2688 ] {36b75687-e003-4b43-b82e-d2e2b6f93e6d} 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af80b71 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80746 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d34b5ca 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000002d3486e4 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000002d34827b 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002d36bcf7 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 12. asan_thread_start(void*) @ 0x000000000aa43059 13. ? @ 0x00007f35aab92ac3 14. ? @ 0x00007f35aac24850 2025.09.09 14:51:17.533443 [ 3604 ] {11fd09ca-c5a9-49e3-a423-b6e04b43348f} executeQuery: Code: 60. DB::Exception: Unknown table expression identifier 'test.hits' in scope SELECT CounterID, min(WatchID), max(WatchID) FROM test.hits GROUP BY CounterID ORDER BY count() DESC LIMIT 20. (UNKNOWN_TABLE) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:56888) (comment: 00050_min_max.sql) (in query: SELECT CounterID, min(WatchID), max(WatchID) FROM test.hits GROUP BY CounterID ORDER BY count() DESC LIMIT 20;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000c44a97a 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4229: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283b8590 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5417: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002835acd8 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000028359104 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000028357f0d 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002921bdcc 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&) @ 0x000000002941f313 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&) @ 0x0000000029419aef 11. ./contrib/llvm-project/libcxx/include/vector:432: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000029421f5d 12. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000029344c1b 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*) @ 0x0000000029b3703b 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 16. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 20. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 21. asan_thread_start(void*) @ 0x000000000aa43059 22. ? @ 0x00007f35aab92ac3 23. ? @ 0x00007f35aac24850 2025.09.09 14:51:17.550879 [ 3604 ] {11fd09ca-c5a9-49e3-a423-b6e04b43348f} TCPHandler: Code: 60. DB::Exception: Unknown table expression identifier 'test.hits' in scope SELECT CounterID, min(WatchID), max(WatchID) FROM test.hits GROUP BY CounterID ORDER BY count() DESC LIMIT 20. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000c44a97a 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4229: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283b8590 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5417: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002835acd8 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000028359104 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000028357f0d 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002921bdcc 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&) @ 0x000000002941f313 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&) @ 0x0000000029419aef 11. ./contrib/llvm-project/libcxx/include/vector:432: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000029421f5d 12. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000029344c1b 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*) @ 0x0000000029b3703b 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 16. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 20. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 21. asan_thread_start(void*) @ 0x000000000aa43059 22. ? @ 0x00007f35aab92ac3 23. ? @ 0x00007f35aac24850 2025.09.09 14:51:17.978524 [ 3722 ] {e560c65d-7dec-4a1f-9488-749d12eb6f86} executeQuery: Code: 60. DB::Exception: Unknown table expression identifier 'test.visits' in scope SELECT uniq(UserID), sum(Sign) FROM test.visits WHERE CounterID = 9627212. (UNKNOWN_TABLE) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:56886) (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000c44a97a 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4229: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283b8590 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5417: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002835acd8 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000028359104 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000028357f0d 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002921bdcc 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&) @ 0x000000002941f313 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&) @ 0x0000000029419aef 11. ./contrib/llvm-project/libcxx/include/vector:432: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000029421f5d 12. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000029344c1b 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*) @ 0x0000000029b3703b 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 16. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 20. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 21. asan_thread_start(void*) @ 0x000000000aa43059 22. ? @ 0x00007f35aab92ac3 23. ? @ 0x00007f35aac24850 2025.09.09 14:51:17.988820 [ 3722 ] {e560c65d-7dec-4a1f-9488-749d12eb6f86} TCPHandler: Code: 60. DB::Exception: Unknown table expression identifier 'test.visits' in scope SELECT uniq(UserID), sum(Sign) FROM test.visits WHERE CounterID = 9627212. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000c44a97a 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4229: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283b8590 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5417: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002835acd8 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000028359104 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000028357f0d 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002921bdcc 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&) @ 0x000000002941f313 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&) @ 0x0000000029419aef 11. ./contrib/llvm-project/libcxx/include/vector:432: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000029421f5d 12. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000029344c1b 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*) @ 0x0000000029b3703b 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 16. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 20. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 21. asan_thread_start(void*) @ 0x000000000aa43059 22. ? @ 0x00007f35aab92ac3 23. ? @ 0x00007f35aac24850 2025.09.09 14:51:22.569463 [ 2686 ] {b54da2e7-8db5-418c-b2ef-b0888a8a5d12} executeQuery: Code: 43. DB::Exception: Illegal types of arguments: Map(UUID, UInt16), UInt16 for function arrayElement. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:56832) (comment: 01720_type_map_and_casts.sql) (in query: SELECT m[257], m[1] 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000ac6ad20 4. DB::(anonymous namespace)::FunctionArrayElement::executeMap(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000019f1b179 5. DB::(anonymous namespace)::FunctionArrayElement::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000019f0ae16 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aa8c635 7. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aac91d5 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000cccccfb 9. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccce65c 10. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd2030 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) @ 0x0000000028259428 12. ./contrib/llvm-project/libcxx/include/vector:961: DB::ActionsDAG::updateHeader(DB::Block const&) const @ 0x0000000028256e17 13. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:10: DB::ExpressionTransform::transformHeader(DB::Block const&, DB::ActionsDAG const&) @ 0x000000002d9c2197 14. ./build_docker/./src/Processors/QueryPlan/ExpressionStep.cpp:0: DB::ExpressionStep::ExpressionStep(DB::DataStream const&, DB::ActionsDAG) @ 0x000000002dd8d279 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::(anonymous namespace)::addExpressionStep(DB::QueryPlan&, std::shared_ptr&, String const&, std::unordered_set, std::hash>, std::equal_to>, std::allocator>>&) @ 0x000000002943bd73 16. ./contrib/llvm-project/libcxx/include/string:1499: DB::Planner::buildPlanForQueryNode() @ 0x0000000029434460 17. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x00000000294261fb 18. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000029421552 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1182: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3737e 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 21. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 22. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 26. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 27. asan_thread_start(void*) @ 0x000000000aa43059 28. ? @ 0x00007f35aab92ac3 29. ? @ 0x00007f35aac24850 2025.09.09 14:51:22.578395 [ 2686 ] {b54da2e7-8db5-418c-b2ef-b0888a8a5d12} TCPHandler: Code: 43. DB::Exception: Illegal types of arguments: Map(UUID, UInt16), UInt16 for function arrayElement. (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000ac6ad20 4. DB::(anonymous namespace)::FunctionArrayElement::executeMap(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000019f1b179 5. DB::(anonymous namespace)::FunctionArrayElement::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000019f0ae16 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aa8c635 7. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aac91d5 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000cccccfb 9. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccce65c 10. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd2030 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) @ 0x0000000028259428 12. ./contrib/llvm-project/libcxx/include/vector:961: DB::ActionsDAG::updateHeader(DB::Block const&) const @ 0x0000000028256e17 13. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:10: DB::ExpressionTransform::transformHeader(DB::Block const&, DB::ActionsDAG const&) @ 0x000000002d9c2197 14. ./build_docker/./src/Processors/QueryPlan/ExpressionStep.cpp:0: DB::ExpressionStep::ExpressionStep(DB::DataStream const&, DB::ActionsDAG) @ 0x000000002dd8d279 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::(anonymous namespace)::addExpressionStep(DB::QueryPlan&, std::shared_ptr&, String const&, std::unordered_set, std::hash>, std::equal_to>, std::allocator>>&) @ 0x000000002943bd73 16. ./contrib/llvm-project/libcxx/include/string:1499: DB::Planner::buildPlanForQueryNode() @ 0x0000000029434460 17. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x00000000294261fb 18. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000029421552 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1182: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3737e 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 21. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 22. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 26. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 27. asan_thread_start(void*) @ 0x000000000aa43059 28. ? @ 0x00007f35aab92ac3 29. ? @ 0x00007f35aac24850 2025.09.09 14:51:22.840670 [ 2686 ] {980379ab-6308-4b98-bb17-758abf84b5c2} executeQuery: Code: 57. DB::Exception: Table test_1.table_map_with_key_integer already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:56832) (comment: 01720_type_map_and_casts.sql) (in query: CREATE TABLE table_map_with_key_integer (`d` DATE, `m` Map(Int128, String)) ENGINE = MergeTree ORDER BY d SETTINGS index_granularity = 39556, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 0., replace_long_file_name_to_hash = true, max_file_name_length = 18, min_bytes_for_full_part_storage = 350853792, compact_parts_max_bytes_to_buffer = 387371480, compact_parts_max_granules_to_buffer = 74, compact_parts_merge_max_bytes_to_prefetch_part = 26473332, merge_max_block_size = 7717, old_parts_lifetime = 128., prefer_fetch_merged_part_size_threshold = 10737418240, vertical_merge_algorithm_min_rows_to_activate = 1, vertical_merge_algorithm_min_columns_to_activate = 100, min_merge_bytes_to_use_direct_io = 1, index_granularity_bytes = 16918709, concurrent_part_removal_threshold = 100, allow_vertical_merges_from_compact_to_wide_parts = true, cache_populated_by_fetch = true, marks_compress_block_size = 70326, primary_key_compress_block_size = 44896), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa91e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1558: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291bc5ff 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291ac835 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000291c3415 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b382fc 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 15. asan_thread_start(void*) @ 0x000000000aa43059 16. ? @ 0x00007f35aab92ac3 17. ? @ 0x00007f35aac24850 2025.09.09 14:51:22.845921 [ 2686 ] {980379ab-6308-4b98-bb17-758abf84b5c2} TCPHandler: Code: 57. DB::Exception: Table test_1.table_map_with_key_integer already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa91e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1558: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291bc5ff 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291ac835 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000291c3415 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b382fc 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 15. asan_thread_start(void*) @ 0x000000000aa43059 16. ? @ 0x00007f35aab92ac3 17. ? @ 0x00007f35aac24850 2025.09.09 14:51:26.824209 [ 3604 ] {8740a2eb-1a3e-4473-ba1b-ea1189c8e998} 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.10505.altinitytest (altinity build)) (from [::1]:42830) (comment: 01060_shutdown_table_after_detach.sql) (in query: ATTACH TABLE test;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af819ed 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80746 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000263a174e 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002c45ab11 8. ./contrib/llvm-project/libcxx/include/vector:1454: DB::MergeTreeData::loadDataParts(bool, std::optional, std::equal_to, std::allocator>>) @ 0x000000002c45eedc 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>) @ 0x000000002cbacf28 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:1460: std::shared_ptr std::allocate_shared[abi:v15007], DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, void>(std::allocator const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&) @ 0x000000002cbabafa 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:962: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000002cba21b8 12. ./build_docker/./src/Storages/StorageFactory.cpp:225: DB::StorageFactory::get(DB::ASTCreateQuery const&, String const&, std::shared_ptr, std::shared_ptr, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, DB::LoadingStrictnessLevel) const @ 0x000000002b77bf53 13. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291b9254 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291ac835 15. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000291c3415 16. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b382fc 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 19. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 23. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 24. asan_thread_start(void*) @ 0x000000000aa43059 25. ? @ 0x00007f35aab92ac3 26. ? @ 0x00007f35aac24850 2025.09.09 14:51:26.877918 [ 3604 ] {8740a2eb-1a3e-4473-ba1b-ea1189c8e998} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=8, jobs=8). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af819ed 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80746 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000263a174e 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002c45ab11 8. ./contrib/llvm-project/libcxx/include/vector:1454: DB::MergeTreeData::loadDataParts(bool, std::optional, std::equal_to, std::allocator>>) @ 0x000000002c45eedc 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>) @ 0x000000002cbacf28 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:1460: std::shared_ptr std::allocate_shared[abi:v15007], DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, void>(std::allocator const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&) @ 0x000000002cbabafa 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:962: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000002cba21b8 12. ./build_docker/./src/Storages/StorageFactory.cpp:225: DB::StorageFactory::get(DB::ASTCreateQuery const&, String const&, std::shared_ptr, std::shared_ptr, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, DB::LoadingStrictnessLevel) const @ 0x000000002b77bf53 13. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291b9254 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291ac835 15. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000291c3415 16. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b382fc 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 19. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 23. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 24. asan_thread_start(void*) @ 0x000000000aa43059 25. ? @ 0x00007f35aab92ac3 26. ? @ 0x00007f35aac24850 2025.09.09 14:51:31.503336 [ 3766 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 14:51:31.515372 [ 2686 ] {10365b95-9308-4a63-8763-9a3df86a5ab3} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=3, jobs=0): (while reading column StartURL): (while reading from part /var/lib/clickhouse/store/3c4/3c446895-044a-4a1d-ba02-d1c9dd0691d8/201403_1_1_0/ in table test.visits (3c446895-044a-4a1d-ba02-d1c9dd0691d8) located on disk default of type local, from mark 0 with max_rows_to_read = 14008): While executing MergeTreeSelect(pool: ReadPool, algorithm: Thread). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:42940) (comment: 00044_any_left_join_string.sql) (in query: SELECT domain, hits, visits FROM ( SELECT domain(URL) AS domain, count() AS hits FROM test.hits GROUP BY domain ) ANY LEFT JOIN ( SELECT domain(StartURL) AS domain, sum(Sign) AS visits FROM test.visits GROUP BY domain ) USING domain 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af80b71 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80746 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000266005a2 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000265fffb4 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:1197: ? @ 0x00000000265fd4e7 9. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:62: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x00000000265e6fbd 10. ./contrib/llvm-project/libcxx/include/future:1123: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x00000000265e7bb3 11. DB::ReadBuffer::next() @ 0x000000000b528aeb 12. DB::ReadBuffer::readStrict(char*, unsigned long) @ 0x000000000b581216 13. ./build_docker/./src/Compression/CompressedReadBufferBase.cpp:0: DB::CompressedReadBufferBase::readCompressedData(unsigned long&, unsigned long&, bool) @ 0x000000002775f390 14. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:22: DB::CompressedReadBufferFromFile::nextImpl() @ 0x0000000027763d41 15. DB::ReadBuffer::next() @ 0x000000000b528aeb 16. ./build_docker/./src/DataTypes/Serializations/SerializationString.cpp:159: void DB::deserializeBinarySSE2<4>(DB::PODArray, 63ul, 64ul>&, DB::PODArray, 63ul, 64ul>&, DB::ReadBuffer&, unsigned long) @ 0x0000000027c0f641 17. ./build_docker/./src/DataTypes/Serializations/SerializationString.cpp:0: DB::SerializationString::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x0000000027c0ecfa 18. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:0: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x0000000027aa00db 19. ./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) @ 0x000000002c80211e 20. ./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>>&) @ 0x000000002c800e8d 21. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:118: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7c9d8a 22. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x000000002c7e0473 23. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x000000002c7dbec3 24. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:0: DB::MergeTreeReadTask::read(DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002c82d05b 25. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:38: DB::MergeTreeThreadSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&, DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002de66094 26. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:0: DB::MergeTreeSelectProcessor::read() @ 0x000000002c8242f9 27. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000002de6d77a 28. ./build_docker/./src/Processors/ISource.cpp:0: DB::ISource::work() @ 0x000000002d3290a1 29. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 30. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 31. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:381: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000002d34bd35 2025.09.09 14:51:31.572389 [ 2686 ] {10365b95-9308-4a63-8763-9a3df86a5ab3} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=3, jobs=0): (while reading column StartURL): (while reading from part /var/lib/clickhouse/store/3c4/3c446895-044a-4a1d-ba02-d1c9dd0691d8/201403_1_1_0/ in table test.visits (3c446895-044a-4a1d-ba02-d1c9dd0691d8) located on disk default of type local, from mark 0 with max_rows_to_read = 14008): 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af80b71 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80746 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000266005a2 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000265fffb4 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:1197: ? @ 0x00000000265fd4e7 9. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:62: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x00000000265e6fbd 10. ./contrib/llvm-project/libcxx/include/future:1123: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x00000000265e7bb3 11. DB::ReadBuffer::next() @ 0x000000000b528aeb 12. DB::ReadBuffer::readStrict(char*, unsigned long) @ 0x000000000b581216 13. ./build_docker/./src/Compression/CompressedReadBufferBase.cpp:0: DB::CompressedReadBufferBase::readCompressedData(unsigned long&, unsigned long&, bool) @ 0x000000002775f390 14. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:22: DB::CompressedReadBufferFromFile::nextImpl() @ 0x0000000027763d41 15. DB::ReadBuffer::next() @ 0x000000000b528aeb 16. ./build_docker/./src/DataTypes/Serializations/SerializationString.cpp:159: void DB::deserializeBinarySSE2<4>(DB::PODArray, 63ul, 64ul>&, DB::PODArray, 63ul, 64ul>&, DB::ReadBuffer&, unsigned long) @ 0x0000000027c0f641 17. ./build_docker/./src/DataTypes/Serializations/SerializationString.cpp:0: DB::SerializationString::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x0000000027c0ecfa 18. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:0: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x0000000027aa00db 19. ./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) @ 0x000000002c80211e 20. ./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>>&) @ 0x000000002c800e8d 21. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:118: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7c9d8a 22. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x000000002c7e0473 23. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x000000002c7dbec3 24. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:0: DB::MergeTreeReadTask::read(DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002c82d05b 25. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:38: DB::MergeTreeThreadSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&, DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002de66094 26. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:0: DB::MergeTreeSelectProcessor::read() @ 0x000000002c8242f9 27. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000002de6d77a 28. ./build_docker/./src/Processors/ISource.cpp:0: DB::ISource::work() @ 0x000000002d3290a1 29. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 30. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 31. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:381: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000002d34bd35 2025.09.09 14:51:32.044756 [ 3766 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 14:51:33.217064 [ 3766 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 14:51:34.464633 [ 3651 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 14:51:35.753102 [ 3651 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 14:51:36.934079 [ 3651 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 14:51:37.494804 [ 2686 ] {296916b8-dae3-465f-b46a-c37164fb084d} executeQuery: Code: 48. DB::Exception: ReplicatedMergeTree (table test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685)) does not support transactions. (NOT_IMPLEMENTED) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:49138) (comment: 01017_mutations_with_nondeterministic_functions_zookeeper.sh) (in query: INSERT INTO table_1017_1 VALUES ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000aad4b34 4. ./build_docker/./src/Interpreters/IInterpreter.cpp:50: DB::IInterpreter::checkStorageSupportsTransactionsIfNeeded(std::shared_ptr const&, std::shared_ptr, bool) @ 0x0000000029189c1e 5. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:751: DB::InterpreterInsertQuery::execute() @ 0x000000002935ad6d 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b382fc 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 9. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 13. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 14. asan_thread_start(void*) @ 0x000000000aa43059 15. ? @ 0x00007f35aab92ac3 16. ? @ 0x00007f35aac24850 2025.09.09 14:51:37.500735 [ 2686 ] {296916b8-dae3-465f-b46a-c37164fb084d} TCPHandler: Code: 48. DB::Exception: ReplicatedMergeTree (table test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000aad4b34 4. ./build_docker/./src/Interpreters/IInterpreter.cpp:50: DB::IInterpreter::checkStorageSupportsTransactionsIfNeeded(std::shared_ptr const&, std::shared_ptr, bool) @ 0x0000000029189c1e 5. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:751: DB::InterpreterInsertQuery::execute() @ 0x000000002935ad6d 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b382fc 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 9. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 13. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 14. asan_thread_start(void*) @ 0x000000000aa43059 15. ? @ 0x00007f35aab92ac3 16. ? @ 0x00007f35aac24850 2025.09.09 14:51:38.034271 [ 4017 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 14:51:38.181223 [ 4018 ] {b7193c13-b840-4516-8b93-74d3a5d6ab09} executeQuery: Code: 48. DB::Exception: ReplicatedMergeTree (table test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685)) does not support transactions. (NOT_IMPLEMENTED) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:50064) (comment: 01017_mutations_with_nondeterministic_functions_zookeeper.sh) (in query: ALTER TABLE table_1017_1 DELETE WHERE ignore(rand())), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000aad4b34 4. ./build_docker/./src/Interpreters/IInterpreter.cpp:50: DB::IInterpreter::checkStorageSupportsTransactionsIfNeeded(std::shared_ptr const&, std::shared_ptr, bool) @ 0x0000000029189c1e 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000029172432 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x0000000029170711 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b382fc 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 15. asan_thread_start(void*) @ 0x000000000aa43059 16. ? @ 0x00007f35aab92ac3 17. ? @ 0x00007f35aac24850 2025.09.09 14:51:38.204321 [ 4018 ] {b7193c13-b840-4516-8b93-74d3a5d6ab09} TCPHandler: Code: 48. DB::Exception: ReplicatedMergeTree (table test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000aad4b34 4. ./build_docker/./src/Interpreters/IInterpreter.cpp:50: DB::IInterpreter::checkStorageSupportsTransactionsIfNeeded(std::shared_ptr const&, std::shared_ptr, bool) @ 0x0000000029189c1e 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000029172432 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x0000000029170711 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b382fc 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 15. asan_thread_start(void*) @ 0x000000000aa43059 16. ? @ 0x00007f35aab92ac3 17. ? @ 0x00007f35aac24850 2025.09.09 14:51:38.907248 [ 3651 ] {4fa7c43c-894b-46c9-a44c-e7b7104fa48b} executeQuery: Code: 48. DB::Exception: ReplicatedMergeTree (table test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685)) does not support transactions. (NOT_IMPLEMENTED) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:50074) (comment: 01017_mutations_with_nondeterministic_functions_zookeeper.sh) (in query: ALTER TABLE table_1017_1 UPDATE y = y + rand() % 1 WHERE not ignore()), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000aad4b34 4. ./build_docker/./src/Interpreters/IInterpreter.cpp:50: DB::IInterpreter::checkStorageSupportsTransactionsIfNeeded(std::shared_ptr const&, std::shared_ptr, bool) @ 0x0000000029189c1e 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000029172432 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x0000000029170711 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b382fc 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 15. asan_thread_start(void*) @ 0x000000000aa43059 16. ? @ 0x00007f35aab92ac3 17. ? @ 0x00007f35aac24850 2025.09.09 14:51:38.932509 [ 3651 ] {4fa7c43c-894b-46c9-a44c-e7b7104fa48b} TCPHandler: Code: 48. DB::Exception: ReplicatedMergeTree (table test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000aad4b34 4. ./build_docker/./src/Interpreters/IInterpreter.cpp:50: DB::IInterpreter::checkStorageSupportsTransactionsIfNeeded(std::shared_ptr const&, std::shared_ptr, bool) @ 0x0000000029189c1e 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000029172432 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x0000000029170711 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b382fc 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 15. asan_thread_start(void*) @ 0x000000000aa43059 16. ? @ 0x00007f35aab92ac3 17. ? @ 0x00007f35aac24850 2025.09.09 14:51:39.064386 [ 4017 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 14:51:39.403763 [ 2686 ] {02be4636-f86d-4ad9-8960-04cb7da131be} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=3, jobs=1): (while reading column query_id): (while reading from part /var/lib/clickhouse/store/1e6/1e64423d-b43b-45ea-b85e-a97c07ea6431/202509_1_15_3/ in table system.query_log (1e64423d-b43b-45ea-b85e-a97c07ea6431) located on disk default of type local, from mark 0 with max_rows_to_read = 467): While executing MergeTreeSelect(pool: ReadPool, algorithm: Thread). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:49244) (comment: 00180_no_seek_avoiding_when_reading_from_cache.sh) (in query: -- AsynchronousReaderIgnoredBytes = 0: no seek-avoiding happened -- CachedReadBufferReadFromSourceBytes = 0: sanity check to ensure we read only from cache SELECT ProfileEvents['AsynchronousReaderIgnoredBytes'], ProfileEvents['CachedReadBufferReadFromSourceBytes'] FROM system.query_log WHERE query_id = '02906_read_from_cache_16819' AND type = 'QueryFinish' AND event_date >= yesterday() AND current_database = currentDatabase() ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af80b71 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80746 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000266005a2 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000265fffb4 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:1197: ? @ 0x00000000265fd4e7 9. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:62: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x00000000265e6fbd 10. ./contrib/llvm-project/libcxx/include/future:1123: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x00000000265e7bb3 11. DB::ReadBuffer::next() @ 0x000000000b528aeb 12. ./src/IO/ReadBuffer.h:0: DB::CompressedReadBufferBase::readCompressedData(unsigned long&, unsigned long&, bool) @ 0x000000002775f11b 13. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:22: DB::CompressedReadBufferFromFile::nextImpl() @ 0x0000000027763d41 14. DB::ReadBuffer::next() @ 0x000000000b528aeb 15. ./build_docker/./src/DataTypes/Serializations/SerializationString.cpp:159: void DB::deserializeBinarySSE2<1>(DB::PODArray, 63ul, 64ul>&, DB::PODArray, 63ul, 64ul>&, DB::ReadBuffer&, unsigned long) @ 0x0000000027c11390 16. ./build_docker/./src/DataTypes/Serializations/SerializationString.cpp:259: DB::SerializationString::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x0000000027c0ec00 17. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:0: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x0000000027aa00db 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>>>*) @ 0x000000002c7b254b 19. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7eb79e 20. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:118: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7c9d8a 21. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x000000002c7e0473 22. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x000000002c7dbec3 23. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x000000002c7dbd35 24. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x000000002c7dbd35 25. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x000000002c7dbd35 26. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x000000002c7dbd35 27. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:0: DB::MergeTreeReadTask::read(DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002c82d05b 28. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:38: DB::MergeTreeThreadSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&, DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002de66094 29. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:0: DB::MergeTreeSelectProcessor::read() @ 0x000000002c8242f9 30. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000002de6d77a 31. ./build_docker/./src/Processors/ISource.cpp:0: DB::ISource::work() @ 0x000000002d3290a1 2025.09.09 14:51:39.455856 [ 2686 ] {02be4636-f86d-4ad9-8960-04cb7da131be} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=3, jobs=1): (while reading column query_id): (while reading from part /var/lib/clickhouse/store/1e6/1e64423d-b43b-45ea-b85e-a97c07ea6431/202509_1_15_3/ in table system.query_log (1e64423d-b43b-45ea-b85e-a97c07ea6431) located on disk default of type local, from mark 0 with max_rows_to_read = 467): 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af80b71 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80746 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000266005a2 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000265fffb4 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:1197: ? @ 0x00000000265fd4e7 9. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:62: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x00000000265e6fbd 10. ./contrib/llvm-project/libcxx/include/future:1123: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x00000000265e7bb3 11. DB::ReadBuffer::next() @ 0x000000000b528aeb 12. ./src/IO/ReadBuffer.h:0: DB::CompressedReadBufferBase::readCompressedData(unsigned long&, unsigned long&, bool) @ 0x000000002775f11b 13. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:22: DB::CompressedReadBufferFromFile::nextImpl() @ 0x0000000027763d41 14. DB::ReadBuffer::next() @ 0x000000000b528aeb 15. ./build_docker/./src/DataTypes/Serializations/SerializationString.cpp:159: void DB::deserializeBinarySSE2<1>(DB::PODArray, 63ul, 64ul>&, DB::PODArray, 63ul, 64ul>&, DB::ReadBuffer&, unsigned long) @ 0x0000000027c11390 16. ./build_docker/./src/DataTypes/Serializations/SerializationString.cpp:259: DB::SerializationString::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x0000000027c0ec00 17. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:0: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x0000000027aa00db 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>>>*) @ 0x000000002c7b254b 19. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7eb79e 20. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:118: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7c9d8a 21. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x000000002c7e0473 22. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x000000002c7dbec3 23. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x000000002c7dbd35 24. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x000000002c7dbd35 25. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x000000002c7dbd35 26. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x000000002c7dbd35 27. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:0: DB::MergeTreeReadTask::read(DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002c82d05b 28. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:38: DB::MergeTreeThreadSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&, DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002de66094 29. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:0: DB::MergeTreeSelectProcessor::read() @ 0x000000002c8242f9 30. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000002de6d77a 31. ./build_docker/./src/Processors/ISource.cpp:0: DB::ISource::work() @ 0x000000002d3290a1 2025.09.09 14:51:39.569279 [ 3651 ] {78b72c77-5fae-4841-a2ae-c69cf38ea39d} executeQuery: Code: 48. DB::Exception: ReplicatedMergeTree (table test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685)) does not support transactions. (NOT_IMPLEMENTED) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:50116) (comment: 01017_mutations_with_nondeterministic_functions_zookeeper.sh) (in query: ALTER TABLE table_1017_1 UPDATE y = x + arrayCount(x -> (x + y) % 2, range(y)) WHERE not ignore()), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000aad4b34 4. ./build_docker/./src/Interpreters/IInterpreter.cpp:50: DB::IInterpreter::checkStorageSupportsTransactionsIfNeeded(std::shared_ptr const&, std::shared_ptr, bool) @ 0x0000000029189c1e 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000029172432 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x0000000029170711 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b382fc 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 15. asan_thread_start(void*) @ 0x000000000aa43059 16. ? @ 0x00007f35aab92ac3 17. ? @ 0x00007f35aac24850 2025.09.09 14:51:39.653964 [ 3651 ] {78b72c77-5fae-4841-a2ae-c69cf38ea39d} TCPHandler: Code: 48. DB::Exception: ReplicatedMergeTree (table test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000aad4b34 4. ./build_docker/./src/Interpreters/IInterpreter.cpp:50: DB::IInterpreter::checkStorageSupportsTransactionsIfNeeded(std::shared_ptr const&, std::shared_ptr, bool) @ 0x0000000029189c1e 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000029172432 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x0000000029170711 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b382fc 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 15. asan_thread_start(void*) @ 0x000000000aa43059 16. ? @ 0x00007f35aab92ac3 17. ? @ 0x00007f35aac24850 2025.09.09 14:51:39.973433 [ 4016 ] {2c10cd9f-2789-4332-b7eb-67737af88a6d} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:48498) (comment: 00180_no_seek_avoiding_when_reading_from_cache.sh) (in query: DROP DATABASE IF EXISTS test_gloc6qcb ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aac868e 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x00000000286b57c7 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x00000000291f5630 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:361: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000291edc97 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x00000000291ebf11 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x00000000291eb7ed 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b382fc 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1529: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000029b3ed3f 11. ./build_docker/./src/Server/HTTPHandler.cpp:529: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000002d0662d1 12. ./build_docker/./src/Server/HTTPHandler.cpp:705: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000002d06d139 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000002d1cc337 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 18. asan_thread_start(void*) @ 0x000000000aa43059 19. ? @ 0x00007f35aab92ac3 20. ? @ 0x00007f35aac24850 2025.09.09 14:51:39.983506 [ 4016 ] {2c10cd9f-2789-4332-b7eb-67737af88a6d} DynamicQueryHandler: Code: 219. DB::Exception: New table 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aac868e 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x00000000286b57c7 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x00000000291f5630 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:361: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000291edc97 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x00000000291ebf11 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x00000000291eb7ed 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b382fc 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1529: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000029b3ed3f 11. ./build_docker/./src/Server/HTTPHandler.cpp:529: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000002d0662d1 12. ./build_docker/./src/Server/HTTPHandler.cpp:705: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000002d06d139 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000002d1cc337 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 18. asan_thread_start(void*) @ 0x000000000aa43059 19. ? @ 0x00007f35aab92ac3 20. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:51:40.063924 [ 4018 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 14:51:40.343873 [ 4019 ] {bcde1b59-0830-4663-85a5-75f1c16157a7} executeQuery: Code: 48. DB::Exception: ReplicatedMergeTree (table test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685)) does not support transactions. (NOT_IMPLEMENTED) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:50158) (comment: 01017_mutations_with_nondeterministic_functions_zookeeper.sh) (in query: ALTER TABLE table_1017_1 UPDATE y = x + arrayCount(x -> (rand() + x) % 2, range(y)) WHERE not ignore()), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000aad4b34 4. ./build_docker/./src/Interpreters/IInterpreter.cpp:50: DB::IInterpreter::checkStorageSupportsTransactionsIfNeeded(std::shared_ptr const&, std::shared_ptr, bool) @ 0x0000000029189c1e 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000029172432 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x0000000029170711 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b382fc 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 15. asan_thread_start(void*) @ 0x000000000aa43059 16. ? @ 0x00007f35aab92ac3 17. ? @ 0x00007f35aac24850 2025.09.09 14:51:40.380065 [ 4019 ] {bcde1b59-0830-4663-85a5-75f1c16157a7} TCPHandler: Code: 48. DB::Exception: ReplicatedMergeTree (table test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000aad4b34 4. ./build_docker/./src/Interpreters/IInterpreter.cpp:50: DB::IInterpreter::checkStorageSupportsTransactionsIfNeeded(std::shared_ptr const&, std::shared_ptr, bool) @ 0x0000000029189c1e 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000029172432 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x0000000029170711 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b382fc 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 15. asan_thread_start(void*) @ 0x000000000aa43059 16. ? @ 0x00007f35aab92ac3 17. ? @ 0x00007f35aac24850 2025.09.09 14:51:41.315744 [ 4019 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 14:51:42.347947 [ 4020 ] {b62dce11-e077-4f0e-86ee-26f2197090c2} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=0, jobs=0). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:50196) (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 = 0, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = false, max_file_name_length = 128, min_bytes_for_full_part_storage = 0, compact_parts_max_bytes_to_buffer = 160827835, compact_parts_max_granules_to_buffer = 1, compact_parts_merge_max_bytes_to_prefetch_part = 1196755, merge_max_block_size = 11561, old_parts_lifetime = 434., 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 = 10364054979, concurrent_part_removal_threshold = 100, allow_vertical_merges_from_compact_to_wide_parts = false, cache_populated_by_fetch = true, marks_compress_block_size = 50790, primary_key_compress_block_size = 81862), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af80b71 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80746 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000263a174e 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002c45d4f6 8. ./contrib/llvm-project/libcxx/include/optional:260: DB::StorageMergeTree::StorageMergeTree(DB::StorageID const&, String const&, DB::StorageInMemoryMetadata const&, DB::LoadingStrictnessLevel, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>) @ 0x000000002cbacf28 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:1460: std::shared_ptr std::allocate_shared[abi:v15007], DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, void>(std::allocator const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&) @ 0x000000002cbabafa 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:962: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000002cba21b8 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 @ 0x000000002b77bf53 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291b9254 13. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291ac835 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000291c3415 15. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b382fc 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 18. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 22. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 14:51:42.359429 [ 4020 ] {b62dce11-e077-4f0e-86ee-26f2197090c2} 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af80b71 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80746 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000263a174e 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002c45d4f6 8. ./contrib/llvm-project/libcxx/include/optional:260: DB::StorageMergeTree::StorageMergeTree(DB::StorageID const&, String const&, DB::StorageInMemoryMetadata const&, DB::LoadingStrictnessLevel, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>) @ 0x000000002cbacf28 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:1460: std::shared_ptr std::allocate_shared[abi:v15007], DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, void>(std::allocator const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&) @ 0x000000002cbabafa 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:962: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000002cba21b8 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 @ 0x000000002b77bf53 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291b9254 13. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291ac835 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000291c3415 15. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b382fc 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 18. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 22. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 14:51:42.512068 [ 3651 ] {e0c68681-ba3a-4f7d-be9c-7ae7aac66714} 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.10505.altinitytest (altinity build)) (from [::1]:50226) (comment: 00157_cache_dictionary.sql) (in query: CREATE TABLE test.hits_1m 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 = 31265, min_bytes_for_wide_part = 673871178, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = false, max_file_name_length = 0, min_bytes_for_full_part_storage = 30135567, compact_parts_max_bytes_to_buffer = 404941946, compact_parts_max_granules_to_buffer = 210, compact_parts_merge_max_bytes_to_prefetch_part = 17940607, merge_max_block_size = 7660, old_parts_lifetime = 231., 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 = 29420797, concurrent_part_removal_threshold = 91, allow_vertical_merges_from_compact_to_wide_parts = true, cache_populated_by_fetch = true, marks_compress_block_size = 34665, primary_key_compress_block_size = 24470), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af819ed 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80746 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000263a174e 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002c45d4f6 8. ./contrib/llvm-project/libcxx/include/optional:260: DB::StorageMergeTree::StorageMergeTree(DB::StorageID const&, String const&, DB::StorageInMemoryMetadata const&, DB::LoadingStrictnessLevel, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>) @ 0x000000002cbacf28 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:1460: std::shared_ptr std::allocate_shared[abi:v15007], DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, void>(std::allocator const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&) @ 0x000000002cbabafa 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:962: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000002cba21b8 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 @ 0x000000002b77bf53 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291b9254 13. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291ac835 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000291c3415 15. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b382fc 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 18. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 22. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 14:51:42.535982 [ 3651 ] {e0c68681-ba3a-4f7d-be9c-7ae7aac66714} 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af819ed 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80746 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000263a174e 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002c45d4f6 8. ./contrib/llvm-project/libcxx/include/optional:260: DB::StorageMergeTree::StorageMergeTree(DB::StorageID const&, String const&, DB::StorageInMemoryMetadata const&, DB::LoadingStrictnessLevel, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>) @ 0x000000002cbacf28 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:1460: std::shared_ptr std::allocate_shared[abi:v15007], DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, void>(std::allocator const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&) @ 0x000000002cbabafa 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:962: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000002cba21b8 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 @ 0x000000002b77bf53 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291b9254 13. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291ac835 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000291c3415 15. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b382fc 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 18. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 22. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 14:51:42.734307 [ 4022 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 14:51:42.780358 [ 4018 ] {2e78953d-9a1e-4448-92f6-1cad5d508429} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:48538) (comment: 00174_distinct_in_order.sql) (in query: DROP DATABASE IF EXISTS test_i7mq277i ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aac868e 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x00000000286b57c7 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x00000000291f5630 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:361: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000291edc97 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x00000000291ebf11 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x00000000291eb7ed 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b382fc 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1529: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000029b3ed3f 11. ./build_docker/./src/Server/HTTPHandler.cpp:529: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000002d0662d1 12. ./build_docker/./src/Server/HTTPHandler.cpp:705: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000002d06d139 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000002d1cc337 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 18. asan_thread_start(void*) @ 0x000000000aa43059 19. ? @ 0x00007f35aab92ac3 20. ? @ 0x00007f35aac24850 2025.09.09 14:51:42.791070 [ 4018 ] {2e78953d-9a1e-4448-92f6-1cad5d508429} DynamicQueryHandler: Code: 219. DB::Exception: New table 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aac868e 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x00000000286b57c7 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x00000000291f5630 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:361: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000291edc97 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x00000000291ebf11 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x00000000291eb7ed 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b382fc 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1529: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000029b3ed3f 11. ./build_docker/./src/Server/HTTPHandler.cpp:529: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000002d0662d1 12. ./build_docker/./src/Server/HTTPHandler.cpp:705: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000002d06d139 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000002d1cc337 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 18. asan_thread_start(void*) @ 0x000000000aa43059 19. ? @ 0x00007f35aab92ac3 20. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:51:42.885257 [ 3651 ] {1f3e5626-c456-42f0-b466-dd07d0df2acf} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:48552) (comment: 00174_distinct_in_order.sql) (in query: DROP DATABASE IF EXISTS test_i7mq277i ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aac868e 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x00000000286b57c7 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x00000000291f5630 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:361: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000291edc97 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x00000000291ebf11 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x00000000291eb7ed 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b382fc 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1529: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000029b3ed3f 11. ./build_docker/./src/Server/HTTPHandler.cpp:529: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000002d0662d1 12. ./build_docker/./src/Server/HTTPHandler.cpp:705: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000002d06d139 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000002d1cc337 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 18. asan_thread_start(void*) @ 0x000000000aa43059 19. ? @ 0x00007f35aab92ac3 20. ? @ 0x00007f35aac24850 2025.09.09 14:51:42.892887 [ 3651 ] {1f3e5626-c456-42f0-b466-dd07d0df2acf} DynamicQueryHandler: Code: 219. DB::Exception: New table 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aac868e 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x00000000286b57c7 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x00000000291f5630 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:361: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000291edc97 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x00000000291ebf11 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x00000000291eb7ed 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b382fc 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1529: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000029b3ed3f 11. ./build_docker/./src/Server/HTTPHandler.cpp:529: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000002d0662d1 12. ./build_docker/./src/Server/HTTPHandler.cpp:705: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000002d06d139 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000002d1cc337 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 18. asan_thread_start(void*) @ 0x000000000aa43059 19. ? @ 0x00007f35aab92ac3 20. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:51:43.162569 [ 4022 ] {539f93c6-998a-4fab-aef3-0703faa20281} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:48562) (comment: 00174_distinct_in_order.sql) (in query: DROP DATABASE IF EXISTS test_i7mq277i ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aac868e 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x00000000286b57c7 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x00000000291f5630 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:361: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000291edc97 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x00000000291ebf11 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x00000000291eb7ed 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b382fc 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1529: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000029b3ed3f 11. ./build_docker/./src/Server/HTTPHandler.cpp:529: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000002d0662d1 12. ./build_docker/./src/Server/HTTPHandler.cpp:705: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000002d06d139 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000002d1cc337 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 18. asan_thread_start(void*) @ 0x000000000aa43059 19. ? @ 0x00007f35aab92ac3 20. ? @ 0x00007f35aac24850 2025.09.09 14:51:43.165783 [ 4022 ] {539f93c6-998a-4fab-aef3-0703faa20281} DynamicQueryHandler: Code: 219. DB::Exception: New table 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aac868e 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x00000000286b57c7 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x00000000291f5630 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:361: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000291edc97 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x00000000291ebf11 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x00000000291eb7ed 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b382fc 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1529: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000029b3ed3f 11. ./build_docker/./src/Server/HTTPHandler.cpp:529: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000002d0662d1 12. ./build_docker/./src/Server/HTTPHandler.cpp:705: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000002d06d139 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000002d1cc337 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 18. asan_thread_start(void*) @ 0x000000000aa43059 19. ? @ 0x00007f35aab92ac3 20. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:51:43.269733 [ 3651 ] {12946f32-175b-4d76-8807-da3ed48f2f2f} executeQuery: Code: 48. DB::Exception: ReplicatedMergeTree (table test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685)) does not support transactions. (NOT_IMPLEMENTED) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:50272) (comment: 01017_mutations_with_nondeterministic_functions_zookeeper.sh) (in query: ALTER TABLE table_1017_1 UPDATE y = joinGet('test_woql9y2m.lookup_table', 'y_new', y) WHERE x=1), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000aad4b34 4. ./build_docker/./src/Interpreters/IInterpreter.cpp:50: DB::IInterpreter::checkStorageSupportsTransactionsIfNeeded(std::shared_ptr const&, std::shared_ptr, bool) @ 0x0000000029189c1e 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000029172432 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x0000000029170711 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b382fc 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 15. asan_thread_start(void*) @ 0x000000000aa43059 16. ? @ 0x00007f35aab92ac3 17. ? @ 0x00007f35aac24850 2025.09.09 14:51:43.274089 [ 3651 ] {12946f32-175b-4d76-8807-da3ed48f2f2f} TCPHandler: Code: 48. DB::Exception: ReplicatedMergeTree (table test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000aad4b34 4. ./build_docker/./src/Interpreters/IInterpreter.cpp:50: DB::IInterpreter::checkStorageSupportsTransactionsIfNeeded(std::shared_ptr const&, std::shared_ptr, bool) @ 0x0000000029189c1e 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000029172432 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x0000000029170711 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b382fc 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 15. asan_thread_start(void*) @ 0x000000000aa43059 16. ? @ 0x00007f35aab92ac3 17. ? @ 0x00007f35aac24850 2025.09.09 14:51:43.814262 [ 4022 ] {13ec957d-b464-4dfe-bf17-b7014fee1a1c} executeQuery: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:50276) (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x0000000026f807e3 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x000000002853b6ad 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterSetQuery::executeForCurrentContext(bool) @ 0x00000000294f6701 9. ./src/Interpreters/InterpreterSetQuery.h:14: DB::applySettingsFromSelectWithUnion(DB::ASTSelectWithUnionQuery const&, std::shared_ptr) @ 0x00000000294f7ccd 10. ./build_docker/./src/Interpreters/InterpreterSetQuery.cpp:65: DB::InterpreterSetQuery::applySettingsFromQuery(std::shared_ptr const&, std::shared_ptr) @ 0x00000000294f6e01 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterSetQuery::applySettingsFromQuery(std::shared_ptr const&, std::shared_ptr) @ 0x00000000294f7439 12. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b33ca4 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 15. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 19. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 20. asan_thread_start(void*) @ 0x000000000aa43059 21. ? @ 0x00007f35aab92ac3 22. ? @ 0x00007f35aac24850 2025.09.09 14:51:43.886414 [ 4022 ] {13ec957d-b464-4dfe-bf17-b7014fee1a1c} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x0000000026f807e3 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x000000002853b6ad 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterSetQuery::executeForCurrentContext(bool) @ 0x00000000294f6701 9. ./src/Interpreters/InterpreterSetQuery.h:14: DB::applySettingsFromSelectWithUnion(DB::ASTSelectWithUnionQuery const&, std::shared_ptr) @ 0x00000000294f7ccd 10. ./build_docker/./src/Interpreters/InterpreterSetQuery.cpp:65: DB::InterpreterSetQuery::applySettingsFromQuery(std::shared_ptr const&, std::shared_ptr) @ 0x00000000294f6e01 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterSetQuery::applySettingsFromQuery(std::shared_ptr const&, std::shared_ptr) @ 0x00000000294f7439 12. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b33ca4 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 15. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 19. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 20. asan_thread_start(void*) @ 0x000000000aa43059 21. ? @ 0x00007f35aab92ac3 22. ? @ 0x00007f35aac24850 2025.09.09 14:51:44.028622 [ 4020 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 14:51:44.097525 [ 4023 ] {55b7a123-d37e-41cc-8163-6a0c9f30e603} executeQuery: Code: 48. DB::Exception: ReplicatedMergeTree (table test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685)) does not support transactions. (NOT_IMPLEMENTED) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:50294) (comment: 01017_mutations_with_nondeterministic_functions_zookeeper.sh) (in query: ALTER TABLE table_1017_1 DELETE WHERE dictHas('test_woql9y2m.dict1', toUInt64(x))), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000aad4b34 4. ./build_docker/./src/Interpreters/IInterpreter.cpp:50: DB::IInterpreter::checkStorageSupportsTransactionsIfNeeded(std::shared_ptr const&, std::shared_ptr, bool) @ 0x0000000029189c1e 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000029172432 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x0000000029170711 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b382fc 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 15. asan_thread_start(void*) @ 0x000000000aa43059 16. ? @ 0x00007f35aab92ac3 17. ? @ 0x00007f35aac24850 2025.09.09 14:51:44.143166 [ 4023 ] {55b7a123-d37e-41cc-8163-6a0c9f30e603} TCPHandler: Code: 48. DB::Exception: ReplicatedMergeTree (table test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000aad4b34 4. ./build_docker/./src/Interpreters/IInterpreter.cpp:50: DB::IInterpreter::checkStorageSupportsTransactionsIfNeeded(std::shared_ptr const&, std::shared_ptr, bool) @ 0x0000000029189c1e 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000029172432 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x0000000029170711 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b382fc 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 15. asan_thread_start(void*) @ 0x000000000aa43059 16. ? @ 0x00007f35aab92ac3 17. ? @ 0x00007f35aac24850 2025.09.09 14:51:44.920574 [ 3722 ] {364fe9ff-e5ee-4a42-8af4-6cecab6f7be7} executeQuery: Code: 48. DB::Exception: ReplicatedMergeTree (table test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685)) does not support transactions. (NOT_IMPLEMENTED) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:50312) (comment: 01017_mutations_with_nondeterministic_functions_zookeeper.sh) (in query: ALTER TABLE table_1017_1 DELETE WHERE dictHas('test_woql9y2m.dict1', toUInt64(x))), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000aad4b34 4. ./build_docker/./src/Interpreters/IInterpreter.cpp:50: DB::IInterpreter::checkStorageSupportsTransactionsIfNeeded(std::shared_ptr const&, std::shared_ptr, bool) @ 0x0000000029189c1e 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000029172432 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x0000000029170711 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b382fc 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 15. asan_thread_start(void*) @ 0x000000000aa43059 16. ? @ 0x00007f35aab92ac3 17. ? @ 0x00007f35aac24850 2025.09.09 14:51:44.927451 [ 3722 ] {364fe9ff-e5ee-4a42-8af4-6cecab6f7be7} TCPHandler: Code: 48. DB::Exception: ReplicatedMergeTree (table test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000aad4b34 4. ./build_docker/./src/Interpreters/IInterpreter.cpp:50: DB::IInterpreter::checkStorageSupportsTransactionsIfNeeded(std::shared_ptr const&, std::shared_ptr, bool) @ 0x0000000029189c1e 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000029172432 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x0000000029170711 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b382fc 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 15. asan_thread_start(void*) @ 0x000000000aa43059 16. ? @ 0x00007f35aab92ac3 17. ? @ 0x00007f35aac24850 2025.09.09 14:51:45.086951 [ 3722 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 14:51:45.519297 [ 4022 ] {6e8f1f17-cddc-4cb0-98c2-708f651aba2e} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=8, jobs=1): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:50304) (comment: 00053_replicate_segfault.sql) (in query: SELECT count() > 0 FROM (SELECT ParsedParams.Key1 AS p FROM test.visits WHERE arrayAll(y -> arrayExists(x -> y != x, p), p)) ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af80b71 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80746 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002c765aab 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:1197: ? @ 0x000000002c7602b8 8. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x000000002c75fc2b 9. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:0: DB::MergeTreeReaderWide::addStream(DB::ISerialization::SubstreamPath const&, String const&) @ 0x000000002c802c31 10. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:0: void std::__function::__policy_invoker::__call_impl const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x000000002c804a95 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000027a9e455 12. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:106: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x0000000027a9ea65 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:100: DB::MergeTreeReaderWide::addStreams(DB::NameAndTypePair const&, std::shared_ptr const&) @ 0x000000002c7fe815 14. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:0: DB::MergeTreeReaderWide::MergeTreeReaderWide(std::shared_ptr, DB::NamesAndTypesList, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*, DB::MarkCache*, DB::MarkRanges, DB::MergeTreeReaderSettings, std::map, std::allocator>>, std::function const&, int) @ 0x000000002c7fdeea 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) @ 0x000000002c5eb9c6 16. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWide.cpp:43: DB::MergeTreeDataPartWide::getReader(DB::NamesAndTypesList const&, std::shared_ptr const&, DB::MarkRanges const&, std::unordered_map, std::equal_to, std::allocator>> const&, DB::UncompressedCache*, DB::MarkCache*, std::shared_ptr const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) const @ 0x000000002c5e354e 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:44: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x000000002c82a56b 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:295: DB::MergeTreeReadPoolBase::createTask(std::shared_ptr, DB::MarkRanges, DB::MergeTreeReadTask*) const @ 0x000000002de9c234 19. ./build_docker/./src/Storages/MergeTree/MergeTreeReadPoolInOrder.cpp:72: DB::MergeTreeReadPoolInOrder::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x000000002deff671 20. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectAlgorithms.cpp:17: DB::MergeTreeInOrderSelectAlgorithm::getNewTask(DB::IMergeTreeReadPool&, DB::MergeTreeReadTask*) @ 0x000000002dea3919 21. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:0: DB::MergeTreeSelectProcessor::read() @ 0x000000002c8241d2 22. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000002de6d77a 23. ./build_docker/./src/Processors/ISource.cpp:0: DB::ISource::work() @ 0x000000002d3290a1 24. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 26. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:381: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000002d34bd35 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7eaf0 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001af8a79f 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 31. asan_thread_start(void*) @ 0x000000000aa43059 2025.09.09 14:51:45.568139 [ 4022 ] {6e8f1f17-cddc-4cb0-98c2-708f651aba2e} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=8, 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af80b71 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80746 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002c765aab 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:1197: ? @ 0x000000002c7602b8 8. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x000000002c75fc2b 9. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:0: DB::MergeTreeReaderWide::addStream(DB::ISerialization::SubstreamPath const&, String const&) @ 0x000000002c802c31 10. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:0: void std::__function::__policy_invoker::__call_impl const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x000000002c804a95 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000027a9e455 12. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:106: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x0000000027a9ea65 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:100: DB::MergeTreeReaderWide::addStreams(DB::NameAndTypePair const&, std::shared_ptr const&) @ 0x000000002c7fe815 14. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:0: DB::MergeTreeReaderWide::MergeTreeReaderWide(std::shared_ptr, DB::NamesAndTypesList, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*, DB::MarkCache*, DB::MarkRanges, DB::MergeTreeReaderSettings, std::map, std::allocator>>, std::function const&, int) @ 0x000000002c7fdeea 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) @ 0x000000002c5eb9c6 16. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWide.cpp:43: DB::MergeTreeDataPartWide::getReader(DB::NamesAndTypesList const&, std::shared_ptr const&, DB::MarkRanges const&, std::unordered_map, std::equal_to, std::allocator>> const&, DB::UncompressedCache*, DB::MarkCache*, std::shared_ptr const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) const @ 0x000000002c5e354e 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:44: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x000000002c82a56b 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:295: DB::MergeTreeReadPoolBase::createTask(std::shared_ptr, DB::MarkRanges, DB::MergeTreeReadTask*) const @ 0x000000002de9c234 19. ./build_docker/./src/Storages/MergeTree/MergeTreeReadPoolInOrder.cpp:72: DB::MergeTreeReadPoolInOrder::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x000000002deff671 20. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectAlgorithms.cpp:17: DB::MergeTreeInOrderSelectAlgorithm::getNewTask(DB::IMergeTreeReadPool&, DB::MergeTreeReadTask*) @ 0x000000002dea3919 21. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:0: DB::MergeTreeSelectProcessor::read() @ 0x000000002c8241d2 22. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000002de6d77a 23. ./build_docker/./src/Processors/ISource.cpp:0: DB::ISource::work() @ 0x000000002d3290a1 24. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 26. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:381: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000002d34bd35 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7eaf0 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001af8a79f 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 31. asan_thread_start(void*) @ 0x000000000aa43059 2025.09.09 14:51:45.937430 [ 3722 ] {6ef598d8-4c97-41d2-9dd6-553edbaf771b} executeQuery: Code: 48. DB::Exception: ReplicatedMergeTree (table test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a)) does not support transactions. (NOT_IMPLEMENTED) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:50334) (comment: 01017_mutations_with_nondeterministic_functions_zookeeper.sh) (in query: DROP TABLE IF EXISTS table_1017_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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000aad4b34 4. ./build_docker/./src/Interpreters/IInterpreter.cpp:50: DB::IInterpreter::checkStorageSupportsTransactionsIfNeeded(std::shared_ptr const&, std::shared_ptr, bool) @ 0x0000000029189c1e 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x00000000291eece1 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x00000000291ed665 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x00000000291ebd68 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x00000000291eb7ed 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b382fc 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 14:51:45.953124 [ 3722 ] {6ef598d8-4c97-41d2-9dd6-553edbaf771b} TCPHandler: Code: 48. DB::Exception: ReplicatedMergeTree (table test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000aad4b34 4. ./build_docker/./src/Interpreters/IInterpreter.cpp:50: DB::IInterpreter::checkStorageSupportsTransactionsIfNeeded(std::shared_ptr const&, std::shared_ptr, bool) @ 0x0000000029189c1e 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x00000000291eece1 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x00000000291ed665 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x00000000291ebd68 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x00000000291eb7ed 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b382fc 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 14:51:46.235352 [ 3722 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 14:51:46.488611 [ 3640 ] {58d68d63-a4f1-4499-a93d-b41c5005e505} executeQuery: Code: 48. DB::Exception: ReplicatedMergeTree (table test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685)) does not support transactions. (NOT_IMPLEMENTED) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:48624) (comment: 01017_mutations_with_nondeterministic_functions_zookeeper.sh) (in query: DROP DATABASE IF EXISTS test_woql9y2m ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000aad4b34 4. ./build_docker/./src/Interpreters/IInterpreter.cpp:50: DB::IInterpreter::checkStorageSupportsTransactionsIfNeeded(std::shared_ptr const&, std::shared_ptr, bool) @ 0x0000000029189c1e 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x00000000291eece1 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>>>&) @ 0x00000000291f510c 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:361: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000291edc97 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x00000000291ebf11 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x00000000291eb7ed 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b382fc 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1529: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000029b3ed3f 12. ./build_docker/./src/Server/HTTPHandler.cpp:529: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000002d0662d1 13. ./build_docker/./src/Server/HTTPHandler.cpp:705: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000002d06d139 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000002d1cc337 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 19. asan_thread_start(void*) @ 0x000000000aa43059 20. ? @ 0x00007f35aab92ac3 21. ? @ 0x00007f35aac24850 2025.09.09 14:51:46.511178 [ 3640 ] {58d68d63-a4f1-4499-a93d-b41c5005e505} DynamicQueryHandler: Code: 48. DB::Exception: ReplicatedMergeTree (table test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000aad4b34 4. ./build_docker/./src/Interpreters/IInterpreter.cpp:50: DB::IInterpreter::checkStorageSupportsTransactionsIfNeeded(std::shared_ptr const&, std::shared_ptr, bool) @ 0x0000000029189c1e 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x00000000291eece1 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>>>&) @ 0x00000000291f510c 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:361: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000291edc97 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x00000000291ebf11 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x00000000291eb7ed 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b382fc 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1529: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000029b3ed3f 12. ./build_docker/./src/Server/HTTPHandler.cpp:529: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000002d0662d1 13. ./build_docker/./src/Server/HTTPHandler.cpp:705: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000002d06d139 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000002d1cc337 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 19. asan_thread_start(void*) @ 0x000000000aa43059 20. ? @ 0x00007f35aab92ac3 21. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:51:46.722963 [ 2833 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:51:47.414165 [ 3722 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 14:51:47.742323 [ 2865 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:51:48.639532 [ 3766 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 14:51:48.744602 [ 2894 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:51:49.746801 [ 2921 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:51:49.889672 [ 4017 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 14:51:50.248716 [ 2688 ] {69accfb3-563c-40a0-a4f9-1fcc0efb72fe} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:59782) (comment: 03091_analyzer_same_table_name_in_different_databases.sql) (in query: DROP DATABASE IF EXISTS test_ab7107tf ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aac868e 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x00000000286b57c7 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x00000000291f5630 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:361: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000291edc97 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x00000000291ebf11 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x00000000291eb7ed 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b382fc 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1529: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000029b3ed3f 11. ./build_docker/./src/Server/HTTPHandler.cpp:529: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000002d0662d1 12. ./build_docker/./src/Server/HTTPHandler.cpp:705: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000002d06d139 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000002d1cc337 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 18. asan_thread_start(void*) @ 0x000000000aa43059 19. ? @ 0x00007f35aab92ac3 20. ? @ 0x00007f35aac24850 2025.09.09 14:51:50.253179 [ 2688 ] {69accfb3-563c-40a0-a4f9-1fcc0efb72fe} DynamicQueryHandler: Code: 219. DB::Exception: New table 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aac868e 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x00000000286b57c7 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x00000000291f5630 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:361: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000291edc97 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x00000000291ebf11 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x00000000291eb7ed 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b382fc 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1529: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000029b3ed3f 11. ./build_docker/./src/Server/HTTPHandler.cpp:529: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000002d0662d1 12. ./build_docker/./src/Server/HTTPHandler.cpp:705: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000002d06d139 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000002d1cc337 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 18. asan_thread_start(void*) @ 0x000000000aa43059 19. ? @ 0x00007f35aab92ac3 20. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:51:50.433185 [ 3640 ] {6558c2db-699f-44e2-ac48-63ed3189b738} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:59796) (comment: 03091_analyzer_same_table_name_in_different_databases.sql) (in query: DROP DATABASE IF EXISTS test_ab7107tf ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aac868e 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x00000000286b57c7 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x00000000291f5630 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:361: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000291edc97 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x00000000291ebf11 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x00000000291eb7ed 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b382fc 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1529: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000029b3ed3f 11. ./build_docker/./src/Server/HTTPHandler.cpp:529: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000002d0662d1 12. ./build_docker/./src/Server/HTTPHandler.cpp:705: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000002d06d139 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000002d1cc337 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 18. asan_thread_start(void*) @ 0x000000000aa43059 19. ? @ 0x00007f35aab92ac3 20. ? @ 0x00007f35aac24850 2025.09.09 14:51:50.435128 [ 3640 ] {6558c2db-699f-44e2-ac48-63ed3189b738} DynamicQueryHandler: Code: 219. DB::Exception: New table 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aac868e 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x00000000286b57c7 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x00000000291f5630 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:361: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000291edc97 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x00000000291ebf11 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x00000000291eb7ed 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b382fc 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1529: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000029b3ed3f 11. ./build_docker/./src/Server/HTTPHandler.cpp:529: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000002d0662d1 12. ./build_docker/./src/Server/HTTPHandler.cpp:705: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000002d06d139 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000002d1cc337 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 18. asan_thread_start(void*) @ 0x000000000aa43059 19. ? @ 0x00007f35aab92ac3 20. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:51:50.589114 [ 2941 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:51:50.624293 [ 3722 ] {a6ad41ac-2db3-41c7-ab64-16828e55a7db} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:59814) (comment: 03091_analyzer_same_table_name_in_different_databases.sql) (in query: DROP DATABASE IF EXISTS test_ab7107tf ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aac868e 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x00000000286b57c7 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x00000000291f5630 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:361: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000291edc97 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x00000000291ebf11 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x00000000291eb7ed 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b382fc 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1529: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000029b3ed3f 11. ./build_docker/./src/Server/HTTPHandler.cpp:529: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000002d0662d1 12. ./build_docker/./src/Server/HTTPHandler.cpp:705: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000002d06d139 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000002d1cc337 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 18. asan_thread_start(void*) @ 0x000000000aa43059 19. ? @ 0x00007f35aab92ac3 20. ? @ 0x00007f35aac24850 2025.09.09 14:51:50.628879 [ 3722 ] {a6ad41ac-2db3-41c7-ab64-16828e55a7db} DynamicQueryHandler: Code: 219. DB::Exception: New table 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aac868e 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x00000000286b57c7 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x00000000291f5630 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:361: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000291edc97 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x00000000291ebf11 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x00000000291eb7ed 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b382fc 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1529: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000029b3ed3f 11. ./build_docker/./src/Server/HTTPHandler.cpp:529: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000002d0662d1 12. ./build_docker/./src/Server/HTTPHandler.cpp:705: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000002d06d139 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000002d1cc337 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 18. asan_thread_start(void*) @ 0x000000000aa43059 19. ? @ 0x00007f35aab92ac3 20. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:51:50.748610 [ 2946 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:51:50.949817 [ 2688 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 14:51:51.567637 [ 4025 ] {d60d073b-03e3-4998-b47a-b25532cfe1e0} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=731, jobs=717). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:39428) (comment: 00047_bar.sql) (in query: SELECT CounterID, count() AS c, bar(c, 0, 523264) FROM test.hits GROUP BY CounterID ORDER BY c DESC, CounterID ASC LIMIT 100;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af872f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af7b2d1 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af7c3f3 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d36920d 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000002d369e5f 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processOrdinaryQuery() @ 0x000000002d18af7b 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d17644a 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 15. asan_thread_start(void*) @ 0x000000000aa43059 16. ? @ 0x00007f35aab92ac3 17. ? @ 0x00007f35aac24850 2025.09.09 14:51:51.590876 [ 4025 ] {d60d073b-03e3-4998-b47a-b25532cfe1e0} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=731, jobs=717). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af872f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af7b2d1 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af7c3f3 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d36920d 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000002d369e5f 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processOrdinaryQuery() @ 0x000000002d18af7b 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d17644a 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 15. asan_thread_start(void*) @ 0x000000000aa43059 16. ? @ 0x00007f35aab92ac3 17. ? @ 0x00007f35aac24850 2025.09.09 14:51:51.591876 [ 2964 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:51:51.751513 [ 2971 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:51:52.124125 [ 3766 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 14:51:52.419052 [ 3640 ] {d0504967-be41-4e6e-a1e1-77fad3c4f3e7} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=8, jobs=2): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:39406) (comment: 00013_sorting_of_nested.sql) (in query: SELECT ParsedParams.Key1 FROM test.visits FINAL WHERE VisitID != 0 AND notEmpty(ParsedParams.Key1) ORDER BY VisitID LIMIT 10 ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af80b71 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80746 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002c765aab 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:1197: ? @ 0x000000002c7602b8 8. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x000000002c75fc2b 9. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:0: DB::MergeTreeReaderWide::addStream(DB::ISerialization::SubstreamPath const&, String const&) @ 0x000000002c802c31 10. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:0: void std::__function::__policy_invoker::__call_impl const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x000000002c804a95 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000027a9e455 12. ./contrib/llvm-project/libcxx/include/vector:1647: DB::SerializationNamed::enumerateStreams(DB::ISerialization::EnumerateStreamsSettings&, std::function const&, DB::ISerialization::SubstreamData const&) const @ 0x0000000027b74737 13. ./build_docker/./src/DataTypes/Serializations/SerializationArray.cpp:0: DB::SerializationArray::enumerateStreams(DB::ISerialization::EnumerateStreamsSettings&, std::function const&, DB::ISerialization::SubstreamData const&) const @ 0x0000000027ab61b5 14. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:106: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x0000000027a9ea65 15. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:100: DB::MergeTreeReaderWide::addStreams(DB::NameAndTypePair const&, std::shared_ptr const&) @ 0x000000002c7fe815 16. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:0: DB::MergeTreeReaderWide::MergeTreeReaderWide(std::shared_ptr, DB::NamesAndTypesList, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*, DB::MarkCache*, DB::MarkRanges, DB::MergeTreeReaderSettings, std::map, std::allocator>>, std::function const&, int) @ 0x000000002c7fdeea 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) @ 0x000000002c5eb9c6 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 @ 0x000000002c5e354e 19. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:44: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x000000002c82a56b 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:295: DB::MergeTreeReadPoolBase::createTask(std::shared_ptr, DB::MarkRanges, DB::MergeTreeReadTask*) const @ 0x000000002de9c234 21. ./build_docker/./src/Storages/MergeTree/MergeTreeReadPoolInOrder.cpp:72: DB::MergeTreeReadPoolInOrder::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x000000002deff671 22. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectAlgorithms.cpp:17: DB::MergeTreeInOrderSelectAlgorithm::getNewTask(DB::IMergeTreeReadPool&, DB::MergeTreeReadTask*) @ 0x000000002dea3919 23. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:0: DB::MergeTreeSelectProcessor::read() @ 0x000000002c8241d2 24. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000002de6d77a 25. ./build_docker/./src/Processors/ISource.cpp:0: DB::ISource::work() @ 0x000000002d3290a1 26. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 27. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 28. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:381: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000002d34bd35 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7eaf0 30. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001af8a79f 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 2025.09.09 14:51:52.440432 [ 3640 ] {d0504967-be41-4e6e-a1e1-77fad3c4f3e7} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=8, 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af80b71 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80746 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002c765aab 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:1197: ? @ 0x000000002c7602b8 8. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x000000002c75fc2b 9. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:0: DB::MergeTreeReaderWide::addStream(DB::ISerialization::SubstreamPath const&, String const&) @ 0x000000002c802c31 10. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:0: void std::__function::__policy_invoker::__call_impl const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x000000002c804a95 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000027a9e455 12. ./contrib/llvm-project/libcxx/include/vector:1647: DB::SerializationNamed::enumerateStreams(DB::ISerialization::EnumerateStreamsSettings&, std::function const&, DB::ISerialization::SubstreamData const&) const @ 0x0000000027b74737 13. ./build_docker/./src/DataTypes/Serializations/SerializationArray.cpp:0: DB::SerializationArray::enumerateStreams(DB::ISerialization::EnumerateStreamsSettings&, std::function const&, DB::ISerialization::SubstreamData const&) const @ 0x0000000027ab61b5 14. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:106: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x0000000027a9ea65 15. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:100: DB::MergeTreeReaderWide::addStreams(DB::NameAndTypePair const&, std::shared_ptr const&) @ 0x000000002c7fe815 16. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:0: DB::MergeTreeReaderWide::MergeTreeReaderWide(std::shared_ptr, DB::NamesAndTypesList, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*, DB::MarkCache*, DB::MarkRanges, DB::MergeTreeReaderSettings, std::map, std::allocator>>, std::function const&, int) @ 0x000000002c7fdeea 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) @ 0x000000002c5eb9c6 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 @ 0x000000002c5e354e 19. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:44: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x000000002c82a56b 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:295: DB::MergeTreeReadPoolBase::createTask(std::shared_ptr, DB::MarkRanges, DB::MergeTreeReadTask*) const @ 0x000000002de9c234 21. ./build_docker/./src/Storages/MergeTree/MergeTreeReadPoolInOrder.cpp:72: DB::MergeTreeReadPoolInOrder::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x000000002deff671 22. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectAlgorithms.cpp:17: DB::MergeTreeInOrderSelectAlgorithm::getNewTask(DB::IMergeTreeReadPool&, DB::MergeTreeReadTask*) @ 0x000000002dea3919 23. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:0: DB::MergeTreeSelectProcessor::read() @ 0x000000002c8241d2 24. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000002de6d77a 25. ./build_docker/./src/Processors/ISource.cpp:0: DB::ISource::work() @ 0x000000002d3290a1 26. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 27. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 28. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:381: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000002d34bd35 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7eaf0 30. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001af8a79f 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 2025.09.09 14:51:52.593849 [ 2985 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:51:52.755682 [ 2989 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:51:53.383236 [ 4016 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 14:51:53.601304 [ 3017 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:51:53.677497 [ 2688 ] {4fa9532d-bf3b-4618-9b69-fbb0bbabcc06} executeQuery: Code: 523. DB::Exception: There is no row policy `p2_01295 ON db.\`table\`` in user directories. (UNKNOWN_ROW_POLICY) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:39414) (comment: 01295_create_row_policy.sql) (in query: SHOW CREATE ROW POLICY p2_01295 ON db.table;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/Exception.h:0: DB::IAccessStorage::throwNotFound(DB::AccessEntityType, String const&) const @ 0x0000000026e7f514 4. ./contrib/llvm-project/libcxx/include/vector:1582: DB::InterpreterShowCreateAccessEntityQuery::getEntities() const @ 0x000000002aa653e6 5. ./contrib/abseil-cpp/absl/container/internal/compressed_tuple.h:90: DB::InterpreterShowCreateAccessEntityQuery::getCreateQueries() const @ 0x000000002aa632ff 6. ./src/Common/COW.h:284: DB::InterpreterShowCreateAccessEntityQuery::executeImpl() @ 0x000000002aa61d63 7. ./build_docker/./src/Interpreters/Access/InterpreterShowCreateAccessEntityQuery.cpp:0: DB::InterpreterShowCreateAccessEntityQuery::execute() @ 0x000000002aa61a7f 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b382fc 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 11. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 15. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 16. asan_thread_start(void*) @ 0x000000000aa43059 17. ? @ 0x00007f35aab92ac3 18. ? @ 0x00007f35aac24850 2025.09.09 14:51:53.695438 [ 2688 ] {4fa9532d-bf3b-4618-9b69-fbb0bbabcc06} TCPHandler: Code: 523. DB::Exception: There is no row policy `p2_01295 ON db.\`table\`` in user directories. (UNKNOWN_ROW_POLICY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/Exception.h:0: DB::IAccessStorage::throwNotFound(DB::AccessEntityType, String const&) const @ 0x0000000026e7f514 4. ./contrib/llvm-project/libcxx/include/vector:1582: DB::InterpreterShowCreateAccessEntityQuery::getEntities() const @ 0x000000002aa653e6 5. ./contrib/abseil-cpp/absl/container/internal/compressed_tuple.h:90: DB::InterpreterShowCreateAccessEntityQuery::getCreateQueries() const @ 0x000000002aa632ff 6. ./src/Common/COW.h:284: DB::InterpreterShowCreateAccessEntityQuery::executeImpl() @ 0x000000002aa61d63 7. ./build_docker/./src/Interpreters/Access/InterpreterShowCreateAccessEntityQuery.cpp:0: DB::InterpreterShowCreateAccessEntityQuery::execute() @ 0x000000002aa61a7f 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b382fc 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 11. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 15. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 16. asan_thread_start(void*) @ 0x000000000aa43059 17. ? @ 0x00007f35aab92ac3 18. ? @ 0x00007f35aac24850 2025.09.09 14:51:53.758660 [ 3024 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:51:54.448982 [ 4016 ] {c59b8828-4273-4a22-9f11-d05abf310da5} executeQuery: Code: 27. DB::Exception: Cannot parse input: expected 'true' before: '}': (while reading the value of key x): (at row 1) : While executing JSONEachRowRowInputFormat. (CANNOT_PARSE_INPUT_ASSERTION_FAILED) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:39500) (comment: 02961_read_bool_as_string_json.sql) (in query: select * from format(JSONEachRow, 'x String', '{"x" : tru}');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::throwAtAssertionFailed(char const*, DB::ReadBuffer&) @ 0x000000001aeb2ed5 4. ./build_docker/./src/IO/ReadHelpers.cpp:101: DB::assertString(char const*, DB::ReadBuffer&) @ 0x000000001aeb3603 5. ./build_docker/./src/DataTypes/Serializations/SerializationString.cpp:0: DB::SerializationString::deserializeTextJSON(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x0000000027c140d5 6. ./build_docker/./src/DataTypes/Serializations/SerializationNullable.cpp:880: DB::SerializationNullable::deserializeNullAsDefaultOrNestedTextJSON(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, std::shared_ptr const&) @ 0x0000000027b7eca2 7. ./build_docker/./src/Formats/JSONUtils.cpp:0: DB::JSONUtils::readField(DB::ReadBuffer&, DB::IColumn&, std::shared_ptr const&, std::shared_ptr const&, String const&, DB::FormatSettings const&, bool) @ 0x000000002d5f1db6 8. ./build_docker/./src/Processors/Formats/Impl/JSONEachRowRowInputFormat.cpp:139: DB::JSONEachRowRowInputFormat::readField(unsigned long, std::vector::mutable_ptr, std::allocator::mutable_ptr>>&) @ 0x000000002d620468 9. ./build_docker/./src/Processors/Formats/Impl/JSONEachRowRowInputFormat.cpp:0: DB::JSONEachRowRowInputFormat::readJSONObject(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&) @ 0x000000002d6209fa 10. ./src/Processors/ISource.h:41: DB::JSONEachRowRowInputFormat::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x000000002d6214a7 11. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:0: DB::IRowInputFormat::read() @ 0x000000002d46d965 12. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000002d37a746 13. ./src/Processors/Chunk.h:110: DB::ISource::tryGenerate() @ 0x000000002d329c18 14. ./build_docker/./src/Processors/ISource.cpp:0: DB::ISource::work() @ 0x000000002d3290a1 15. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 18. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 19. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 20. ./build_docker/./src/TableFunctions/TableFunctionFormat.cpp:0: DB::(anonymous namespace)::TableFunctionFormat::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x000000002603f61e 21. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x00000000265c241e 22. ./build_docker/./src/Interpreters/Context.cpp:2234: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000285361d2 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4819: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000002837024e 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000283ba404 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002835ad09 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000028359104 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000028357f0d 28. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002921bdcc 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002941f313 30. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000029419aef 31. ./contrib/llvm-project/libcxx/include/vector:432: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000029421f5d 2025.09.09 14:51:54.458546 [ 4016 ] {c59b8828-4273-4a22-9f11-d05abf310da5} TCPHandler: Code: 27. DB::Exception: Cannot parse input: expected 'true' before: '}': (while reading the value of key x): (at row 1) : While executing JSONEachRowRowInputFormat. (CANNOT_PARSE_INPUT_ASSERTION_FAILED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::throwAtAssertionFailed(char const*, DB::ReadBuffer&) @ 0x000000001aeb2ed5 4. ./build_docker/./src/IO/ReadHelpers.cpp:101: DB::assertString(char const*, DB::ReadBuffer&) @ 0x000000001aeb3603 5. ./build_docker/./src/DataTypes/Serializations/SerializationString.cpp:0: DB::SerializationString::deserializeTextJSON(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x0000000027c140d5 6. ./build_docker/./src/DataTypes/Serializations/SerializationNullable.cpp:880: DB::SerializationNullable::deserializeNullAsDefaultOrNestedTextJSON(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, std::shared_ptr const&) @ 0x0000000027b7eca2 7. ./build_docker/./src/Formats/JSONUtils.cpp:0: DB::JSONUtils::readField(DB::ReadBuffer&, DB::IColumn&, std::shared_ptr const&, std::shared_ptr const&, String const&, DB::FormatSettings const&, bool) @ 0x000000002d5f1db6 8. ./build_docker/./src/Processors/Formats/Impl/JSONEachRowRowInputFormat.cpp:139: DB::JSONEachRowRowInputFormat::readField(unsigned long, std::vector::mutable_ptr, std::allocator::mutable_ptr>>&) @ 0x000000002d620468 9. ./build_docker/./src/Processors/Formats/Impl/JSONEachRowRowInputFormat.cpp:0: DB::JSONEachRowRowInputFormat::readJSONObject(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&) @ 0x000000002d6209fa 10. ./src/Processors/ISource.h:41: DB::JSONEachRowRowInputFormat::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x000000002d6214a7 11. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:0: DB::IRowInputFormat::read() @ 0x000000002d46d965 12. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000002d37a746 13. ./src/Processors/Chunk.h:110: DB::ISource::tryGenerate() @ 0x000000002d329c18 14. ./build_docker/./src/Processors/ISource.cpp:0: DB::ISource::work() @ 0x000000002d3290a1 15. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 18. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 19. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 20. ./build_docker/./src/TableFunctions/TableFunctionFormat.cpp:0: DB::(anonymous namespace)::TableFunctionFormat::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x000000002603f61e 21. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x00000000265c241e 22. ./build_docker/./src/Interpreters/Context.cpp:2234: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000285361d2 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4819: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000002837024e 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000283ba404 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002835ad09 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000028359104 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000028357f0d 28. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002921bdcc 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002941f313 30. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000029419aef 31. ./contrib/llvm-project/libcxx/include/vector:432: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000029421f5d 2025.09.09 14:51:54.619355 [ 4016 ] {3355d6ce-7f21-4dbd-a12b-6355369683cb} executeQuery: Code: 27. DB::Exception: Cannot parse input: expected 'false' before: '}': (while reading the value of key x): (at row 1) : While executing JSONEachRowRowInputFormat. (CANNOT_PARSE_INPUT_ASSERTION_FAILED) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:39500) (comment: 02961_read_bool_as_string_json.sql) (in query: select * from format(JSONEachRow, 'x String', '{"x" : fals}');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::throwAtAssertionFailed(char const*, DB::ReadBuffer&) @ 0x000000001aeb2ed5 4. ./build_docker/./src/IO/ReadHelpers.cpp:101: DB::assertString(char const*, DB::ReadBuffer&) @ 0x000000001aeb3603 5. ./build_docker/./src/DataTypes/Serializations/SerializationString.cpp:0: DB::SerializationString::deserializeTextJSON(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x0000000027c144ab 6. ./build_docker/./src/DataTypes/Serializations/SerializationNullable.cpp:880: DB::SerializationNullable::deserializeNullAsDefaultOrNestedTextJSON(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, std::shared_ptr const&) @ 0x0000000027b7eca2 7. ./build_docker/./src/Formats/JSONUtils.cpp:0: DB::JSONUtils::readField(DB::ReadBuffer&, DB::IColumn&, std::shared_ptr const&, std::shared_ptr const&, String const&, DB::FormatSettings const&, bool) @ 0x000000002d5f1db6 8. ./build_docker/./src/Processors/Formats/Impl/JSONEachRowRowInputFormat.cpp:139: DB::JSONEachRowRowInputFormat::readField(unsigned long, std::vector::mutable_ptr, std::allocator::mutable_ptr>>&) @ 0x000000002d620468 9. ./build_docker/./src/Processors/Formats/Impl/JSONEachRowRowInputFormat.cpp:0: DB::JSONEachRowRowInputFormat::readJSONObject(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&) @ 0x000000002d6209fa 10. ./src/Processors/ISource.h:41: DB::JSONEachRowRowInputFormat::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x000000002d6214a7 11. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:0: DB::IRowInputFormat::read() @ 0x000000002d46d965 12. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000002d37a746 13. ./src/Processors/Chunk.h:110: DB::ISource::tryGenerate() @ 0x000000002d329c18 14. ./build_docker/./src/Processors/ISource.cpp:0: DB::ISource::work() @ 0x000000002d3290a1 15. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 18. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 19. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 20. ./build_docker/./src/TableFunctions/TableFunctionFormat.cpp:0: DB::(anonymous namespace)::TableFunctionFormat::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x000000002603f61e 21. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x00000000265c241e 22. ./build_docker/./src/Interpreters/Context.cpp:2234: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000285361d2 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4819: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000002837024e 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000283ba404 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002835ad09 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000028359104 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000028357f0d 28. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002921bdcc 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002941f313 30. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000029419aef 31. ./contrib/llvm-project/libcxx/include/vector:432: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000029421f5d 2025.09.09 14:51:54.623452 [ 3651 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 14:51:54.630692 [ 4016 ] {3355d6ce-7f21-4dbd-a12b-6355369683cb} TCPHandler: Code: 27. DB::Exception: Cannot parse input: expected 'false' before: '}': (while reading the value of key x): (at row 1) : While executing JSONEachRowRowInputFormat. (CANNOT_PARSE_INPUT_ASSERTION_FAILED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::throwAtAssertionFailed(char const*, DB::ReadBuffer&) @ 0x000000001aeb2ed5 4. ./build_docker/./src/IO/ReadHelpers.cpp:101: DB::assertString(char const*, DB::ReadBuffer&) @ 0x000000001aeb3603 5. ./build_docker/./src/DataTypes/Serializations/SerializationString.cpp:0: DB::SerializationString::deserializeTextJSON(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x0000000027c144ab 6. ./build_docker/./src/DataTypes/Serializations/SerializationNullable.cpp:880: DB::SerializationNullable::deserializeNullAsDefaultOrNestedTextJSON(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, std::shared_ptr const&) @ 0x0000000027b7eca2 7. ./build_docker/./src/Formats/JSONUtils.cpp:0: DB::JSONUtils::readField(DB::ReadBuffer&, DB::IColumn&, std::shared_ptr const&, std::shared_ptr const&, String const&, DB::FormatSettings const&, bool) @ 0x000000002d5f1db6 8. ./build_docker/./src/Processors/Formats/Impl/JSONEachRowRowInputFormat.cpp:139: DB::JSONEachRowRowInputFormat::readField(unsigned long, std::vector::mutable_ptr, std::allocator::mutable_ptr>>&) @ 0x000000002d620468 9. ./build_docker/./src/Processors/Formats/Impl/JSONEachRowRowInputFormat.cpp:0: DB::JSONEachRowRowInputFormat::readJSONObject(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&) @ 0x000000002d6209fa 10. ./src/Processors/ISource.h:41: DB::JSONEachRowRowInputFormat::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x000000002d6214a7 11. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:0: DB::IRowInputFormat::read() @ 0x000000002d46d965 12. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000002d37a746 13. ./src/Processors/Chunk.h:110: DB::ISource::tryGenerate() @ 0x000000002d329c18 14. ./build_docker/./src/Processors/ISource.cpp:0: DB::ISource::work() @ 0x000000002d3290a1 15. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 18. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 19. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 20. ./build_docker/./src/TableFunctions/TableFunctionFormat.cpp:0: DB::(anonymous namespace)::TableFunctionFormat::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x000000002603f61e 21. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x00000000265c241e 22. ./build_docker/./src/Interpreters/Context.cpp:2234: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000285361d2 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4819: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000002837024e 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000283ba404 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002835ad09 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000028359104 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000028357f0d 28. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002921bdcc 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002941f313 30. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000029419aef 31. ./contrib/llvm-project/libcxx/include/vector:432: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000029421f5d 2025.09.09 14:51:54.724790 [ 3037 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:51:54.761727 [ 3040 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:51:54.868419 [ 4016 ] {d5a7a622-e6e7-4102-817a-8e6bb289ea5c} executeQuery: Code: 117. DB::Exception: Cannot read JSON field here: 'atru}'. Unexpected symbol 'a': (while reading the value of key x): (at row 1) : While executing JSONEachRowRowInputFormat. (INCORRECT_DATA) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:39500) (comment: 02961_read_bool_as_string_json.sql) (in query: select * from format(JSONEachRow, 'x String', '{"x" : atru}');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000ac6ad20 4. ./build_docker/./src/IO/ReadHelpers.cpp:1753: void DB::skipJSONFieldImpl(DB::ReadBuffer&, StringRef, DB::FormatSettings::JSON const&, unsigned long) @ 0x000000001aef1072 5. ./build_docker/./src/IO/ReadHelpers.cpp:1995: DB::readJSONField(String&, DB::ReadBuffer&, DB::FormatSettings::JSON const&) @ 0x000000001aebc743 6. ./build_docker/./src/DataTypes/Serializations/SerializationString.cpp:0: DB::SerializationString::deserializeTextJSON(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x0000000027c14473 7. ./build_docker/./src/DataTypes/Serializations/SerializationNullable.cpp:880: DB::SerializationNullable::deserializeNullAsDefaultOrNestedTextJSON(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, std::shared_ptr const&) @ 0x0000000027b7eca2 8. ./build_docker/./src/Formats/JSONUtils.cpp:0: DB::JSONUtils::readField(DB::ReadBuffer&, DB::IColumn&, std::shared_ptr const&, std::shared_ptr const&, String const&, DB::FormatSettings const&, bool) @ 0x000000002d5f1db6 9. ./build_docker/./src/Processors/Formats/Impl/JSONEachRowRowInputFormat.cpp:139: DB::JSONEachRowRowInputFormat::readField(unsigned long, std::vector::mutable_ptr, std::allocator::mutable_ptr>>&) @ 0x000000002d620468 10. ./build_docker/./src/Processors/Formats/Impl/JSONEachRowRowInputFormat.cpp:0: DB::JSONEachRowRowInputFormat::readJSONObject(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&) @ 0x000000002d6209fa 11. ./src/Processors/ISource.h:41: DB::JSONEachRowRowInputFormat::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x000000002d6214a7 12. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:0: DB::IRowInputFormat::read() @ 0x000000002d46d965 13. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000002d37a746 14. ./src/Processors/Chunk.h:110: DB::ISource::tryGenerate() @ 0x000000002d329c18 15. ./build_docker/./src/Processors/ISource.cpp:0: DB::ISource::work() @ 0x000000002d3290a1 16. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 18. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 19. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 20. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 21. ./build_docker/./src/TableFunctions/TableFunctionFormat.cpp:0: DB::(anonymous namespace)::TableFunctionFormat::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x000000002603f61e 22. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x00000000265c241e 23. ./build_docker/./src/Interpreters/Context.cpp:2234: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000285361d2 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4819: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000002837024e 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000283ba404 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002835ad09 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000028359104 28. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000028357f0d 29. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002921bdcc 30. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002941f313 31. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000029419aef 2025.09.09 14:51:54.871758 [ 4016 ] {d5a7a622-e6e7-4102-817a-8e6bb289ea5c} TCPHandler: Code: 117. DB::Exception: Cannot read JSON field here: 'atru}'. Unexpected symbol 'a': (while reading the value of key x): (at row 1) : While executing JSONEachRowRowInputFormat. (INCORRECT_DATA), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000ac6ad20 4. ./build_docker/./src/IO/ReadHelpers.cpp:1753: void DB::skipJSONFieldImpl(DB::ReadBuffer&, StringRef, DB::FormatSettings::JSON const&, unsigned long) @ 0x000000001aef1072 5. ./build_docker/./src/IO/ReadHelpers.cpp:1995: DB::readJSONField(String&, DB::ReadBuffer&, DB::FormatSettings::JSON const&) @ 0x000000001aebc743 6. ./build_docker/./src/DataTypes/Serializations/SerializationString.cpp:0: DB::SerializationString::deserializeTextJSON(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x0000000027c14473 7. ./build_docker/./src/DataTypes/Serializations/SerializationNullable.cpp:880: DB::SerializationNullable::deserializeNullAsDefaultOrNestedTextJSON(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, std::shared_ptr const&) @ 0x0000000027b7eca2 8. ./build_docker/./src/Formats/JSONUtils.cpp:0: DB::JSONUtils::readField(DB::ReadBuffer&, DB::IColumn&, std::shared_ptr const&, std::shared_ptr const&, String const&, DB::FormatSettings const&, bool) @ 0x000000002d5f1db6 9. ./build_docker/./src/Processors/Formats/Impl/JSONEachRowRowInputFormat.cpp:139: DB::JSONEachRowRowInputFormat::readField(unsigned long, std::vector::mutable_ptr, std::allocator::mutable_ptr>>&) @ 0x000000002d620468 10. ./build_docker/./src/Processors/Formats/Impl/JSONEachRowRowInputFormat.cpp:0: DB::JSONEachRowRowInputFormat::readJSONObject(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&) @ 0x000000002d6209fa 11. ./src/Processors/ISource.h:41: DB::JSONEachRowRowInputFormat::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x000000002d6214a7 12. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:0: DB::IRowInputFormat::read() @ 0x000000002d46d965 13. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000002d37a746 14. ./src/Processors/Chunk.h:110: DB::ISource::tryGenerate() @ 0x000000002d329c18 15. ./build_docker/./src/Processors/ISource.cpp:0: DB::ISource::work() @ 0x000000002d3290a1 16. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 18. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 19. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 20. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 21. ./build_docker/./src/TableFunctions/TableFunctionFormat.cpp:0: DB::(anonymous namespace)::TableFunctionFormat::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x000000002603f61e 22. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x00000000265c241e 23. ./build_docker/./src/Interpreters/Context.cpp:2234: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000285361d2 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4819: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000002837024e 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000283ba404 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002835ad09 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000028359104 28. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000028357f0d 29. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002921bdcc 30. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002941f313 31. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000029419aef 2025.09.09 14:51:55.728916 [ 3065 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:51:55.766168 [ 3064 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:51:55.935644 [ 4016 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 14:51:56.731801 [ 3090 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:51:56.769009 [ 3092 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:51:56.867928 [ 3766 ] {41a2dbf8-850f-4a26-b06a-3ce6247608d0} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=13, jobs=1): While executing MergeTreeSelect(pool: ReadPool, algorithm: Thread). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:39520) (comment: 00040_aggregating_materialized_view.sql) (in query: CREATE MATERIALIZED VIEW test.basic_00040 ENGINE = AggregatingMergeTree(StartDate, (CounterID, StartDate), 8192) POPULATE AS SELECT CounterID, StartDate, sumState(Sign) AS Visits, uniqState(UserID) AS Users FROM test.visits GROUP BY CounterID, StartDate;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af80b71 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80746 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002c765aab 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:1197: ? @ 0x000000002c7602b8 8. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x000000002c75fc2b 9. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:0: DB::MergeTreeReaderWide::addStream(DB::ISerialization::SubstreamPath const&, String const&) @ 0x000000002c802c31 10. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:0: void std::__function::__policy_invoker::__call_impl const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x000000002c804a95 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000027a9e455 12. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:106: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x0000000027a9ea65 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:100: DB::MergeTreeReaderWide::addStreams(DB::NameAndTypePair const&, std::shared_ptr const&) @ 0x000000002c7fe815 14. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:0: DB::MergeTreeReaderWide::MergeTreeReaderWide(std::shared_ptr, DB::NamesAndTypesList, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*, DB::MarkCache*, DB::MarkRanges, DB::MergeTreeReaderSettings, std::map, std::allocator>>, std::function const&, int) @ 0x000000002c7fdeea 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) @ 0x000000002c5eb9c6 16. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWide.cpp:43: DB::MergeTreeDataPartWide::getReader(DB::NamesAndTypesList const&, std::shared_ptr const&, DB::MarkRanges const&, std::unordered_map, std::equal_to, std::allocator>> const&, DB::UncompressedCache*, DB::MarkCache*, std::shared_ptr const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) const @ 0x000000002c5e354e 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:44: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x000000002c82a56b 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:295: DB::MergeTreeReadPoolBase::createTask(std::shared_ptr, DB::MarkRanges, DB::MergeTreeReadTask*) const @ 0x000000002de9c5f2 19. ./build_docker/./src/Storages/MergeTree/MergeTreeReadPool.cpp:144: DB::MergeTreeReadPool::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x000000002def1bcc 20. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:0: DB::MergeTreeSelectProcessor::read() @ 0x000000002c8241d2 21. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000002de6d77a 22. ./build_docker/./src/Processors/ISource.cpp:0: DB::ISource::work() @ 0x000000002d3290a1 23. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:381: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000002d34bd35 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7eaf0 27. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001af8a79f 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 30. asan_thread_start(void*) @ 0x000000000aa43059 31. ? @ 0x00007f35aab92ac3 2025.09.09 14:51:57.008059 [ 3766 ] {41a2dbf8-850f-4a26-b06a-3ce6247608d0} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=13, 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af80b71 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80746 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002c765aab 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:1197: ? @ 0x000000002c7602b8 8. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x000000002c75fc2b 9. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:0: DB::MergeTreeReaderWide::addStream(DB::ISerialization::SubstreamPath const&, String const&) @ 0x000000002c802c31 10. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:0: void std::__function::__policy_invoker::__call_impl const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x000000002c804a95 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000027a9e455 12. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:106: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x0000000027a9ea65 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:100: DB::MergeTreeReaderWide::addStreams(DB::NameAndTypePair const&, std::shared_ptr const&) @ 0x000000002c7fe815 14. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:0: DB::MergeTreeReaderWide::MergeTreeReaderWide(std::shared_ptr, DB::NamesAndTypesList, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*, DB::MarkCache*, DB::MarkRanges, DB::MergeTreeReaderSettings, std::map, std::allocator>>, std::function const&, int) @ 0x000000002c7fdeea 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) @ 0x000000002c5eb9c6 16. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWide.cpp:43: DB::MergeTreeDataPartWide::getReader(DB::NamesAndTypesList const&, std::shared_ptr const&, DB::MarkRanges const&, std::unordered_map, std::equal_to, std::allocator>> const&, DB::UncompressedCache*, DB::MarkCache*, std::shared_ptr const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) const @ 0x000000002c5e354e 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:44: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x000000002c82a56b 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:295: DB::MergeTreeReadPoolBase::createTask(std::shared_ptr, DB::MarkRanges, DB::MergeTreeReadTask*) const @ 0x000000002de9c5f2 19. ./build_docker/./src/Storages/MergeTree/MergeTreeReadPool.cpp:144: DB::MergeTreeReadPool::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x000000002def1bcc 20. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:0: DB::MergeTreeSelectProcessor::read() @ 0x000000002c8241d2 21. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000002de6d77a 22. ./build_docker/./src/Processors/ISource.cpp:0: DB::ISource::work() @ 0x000000002d3290a1 23. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:381: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000002d34bd35 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7eaf0 27. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001af8a79f 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 30. asan_thread_start(void*) @ 0x000000000aa43059 31. ? @ 0x00007f35aab92ac3 2025.09.09 14:51:57.073394 [ 4016 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 14:51:57.735077 [ 3117 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:51:57.772520 [ 3119 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:51:58.366130 [ 2686 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 14:51:58.738146 [ 3135 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:51:58.778558 [ 3138 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:51:58.784840 [ 2688 ] {90d71255-26f0-436a-ad2f-978c04ec02dc} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=731, jobs=723). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:39414) (comment: 01295_create_row_policy.sql) (in query: SELECT '-- multiple policies in one command';), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af872f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af7b2d1 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af7c3f3 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d36920d 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000002d369e5f 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processOrdinaryQuery() @ 0x000000002d18af7b 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d17644a 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 15. asan_thread_start(void*) @ 0x000000000aa43059 16. ? @ 0x00007f35aab92ac3 17. ? @ 0x00007f35aac24850 2025.09.09 14:51:58.786879 [ 2688 ] {90d71255-26f0-436a-ad2f-978c04ec02dc} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=731, jobs=723). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af872f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af7b2d1 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af7c3f3 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d36920d 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000002d369e5f 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processOrdinaryQuery() @ 0x000000002d18af7b 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d17644a 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 15. asan_thread_start(void*) @ 0x000000000aa43059 16. ? @ 0x00007f35aab92ac3 17. ? @ 0x00007f35aac24850 2025.09.09 14:51:59.655562 [ 2686 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 14:51:59.742114 [ 3155 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:51:59.786380 [ 3154 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:52:00.749389 [ 3175 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:52:00.790907 [ 3177 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:52:00.991074 [ 4016 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 14:52:01.754140 [ 3199 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:52:01.802638 [ 3201 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:52:02.375612 [ 4025 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 14:52:02.757323 [ 3223 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:52:02.808195 [ 3224 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:52:03.194788 [ 3651 ] {caf960f3-de34-46ab-9f20-9192407737bd} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=0, jobs=0). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:60396) (comment: 00652_replicated_mutations_default_database_zookeeper.sh) (in query: CREATE TABLE mutations_r1 (`x` UInt32, `y` UInt32) ENGINE = ReplicatedMergeTree('/clickhouse/tables/00652_replicated_mutations_default_database_zookeeper_test_1/mutations', 'r1') ORDER BY x SETTINGS index_granularity = 3301, min_bytes_for_wide_part = 511296206, ratio_of_defaults_for_sparse_serialization = 0., replace_long_file_name_to_hash = true, max_file_name_length = 128, min_bytes_for_full_part_storage = 0, compact_parts_max_bytes_to_buffer = 88784599, compact_parts_max_granules_to_buffer = 256, compact_parts_merge_max_bytes_to_prefetch_part = 3613763, merge_max_block_size = 22224, old_parts_lifetime = 47., 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 = 4418867, concurrent_part_removal_threshold = 3, allow_vertical_merges_from_compact_to_wide_parts = false, cache_populated_by_fetch = true, marks_compress_block_size = 21716, primary_key_compress_block_size = 35094), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af80b71 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80746 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000263a174e 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002c45d4f6 8. ./contrib/llvm-project/libcxx/include/optional:260: DB::StorageReplicatedMergeTree::StorageReplicatedMergeTree(String const&, String const&, DB::LoadingStrictnessLevel, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata const&, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>, DB::RenamingRestrictions, bool) @ 0x000000002ba16434 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:1460: std::shared_ptr std::allocate_shared[abi:v15007], String&, String&, DB::LoadingStrictnessLevel const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, DB::RenamingRestrictions&, bool&, void>(std::allocator const&, String&, String&, DB::LoadingStrictnessLevel const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&, DB::RenamingRestrictions&, bool&) @ 0x000000002cbab63b 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:962: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000002cba1fff 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 @ 0x000000002b77bf53 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291b9254 13. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291ac835 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000291c3415 15. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b382fc 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 18. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 22. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 14:52:03.202140 [ 3651 ] {caf960f3-de34-46ab-9f20-9192407737bd} 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af80b71 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80746 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000263a174e 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002c45d4f6 8. ./contrib/llvm-project/libcxx/include/optional:260: DB::StorageReplicatedMergeTree::StorageReplicatedMergeTree(String const&, String const&, DB::LoadingStrictnessLevel, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata const&, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>, DB::RenamingRestrictions, bool) @ 0x000000002ba16434 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:1460: std::shared_ptr std::allocate_shared[abi:v15007], String&, String&, DB::LoadingStrictnessLevel const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, DB::RenamingRestrictions&, bool&, void>(std::allocator const&, String&, String&, DB::LoadingStrictnessLevel const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&, DB::RenamingRestrictions&, bool&) @ 0x000000002cbab63b 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:962: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000002cba1fff 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 @ 0x000000002b77bf53 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291b9254 13. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291ac835 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000291c3415 15. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b382fc 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 18. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 22. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 14:52:03.584845 [ 4025 ] {54166868-229f-4e1a-8d16-36c15906b7c5} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=0, jobs=0). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:60392) (comment: 00173_group_by_use_nulls.sql) (in query: SELECT CounterID AS k, quantileBFloat16(0.5)(ResolutionWidth) FROM test.hits GROUP BY k ORDER BY count() DESC, CounterID ASC LIMIT 10 SETTINGS group_by_use_nulls = 1 FORMAT Null;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af80b71 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80746 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d34b5ca 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000002d3486e4 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000002d34827b 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002d36bcf7 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 12. asan_thread_start(void*) @ 0x000000000aa43059 13. ? @ 0x00007f35aab92ac3 14. ? @ 0x00007f35aac24850 2025.09.09 14:52:03.590840 [ 4025 ] {54166868-229f-4e1a-8d16-36c15906b7c5} 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af80b71 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80746 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d34b5ca 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000002d3486e4 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000002d34827b 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002d36bcf7 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 12. asan_thread_start(void*) @ 0x000000000aa43059 13. ? @ 0x00007f35aab92ac3 14. ? @ 0x00007f35aac24850 2025.09.09 14:52:03.689962 [ 4016 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 14:52:03.762859 [ 2733 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:52:03.817278 [ 2753 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:52:04.269034 [ 2686 ] {e4df1581-c974-44b7-92ae-40bf5b49728d} executeQuery: Code: 60. DB::Exception: Unknown table expression identifier 'mutations_r1' in scope SELECT * FROM mutations_r1. (UNKNOWN_TABLE) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:60420) (comment: 00652_replicated_mutations_default_database_zookeeper.sh) (in query: SELECT * FROM mutations_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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000c44a97a 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4229: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283b8590 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5417: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002835acd8 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000028359104 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000028357f0d 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002921bdcc 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&) @ 0x000000002941f313 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&) @ 0x0000000029419aef 11. ./contrib/llvm-project/libcxx/include/vector:432: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000029421f5d 12. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000029344c1b 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*) @ 0x0000000029b3703b 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 16. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 20. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 21. asan_thread_start(void*) @ 0x000000000aa43059 22. ? @ 0x00007f35aab92ac3 23. ? @ 0x00007f35aac24850 2025.09.09 14:52:04.281640 [ 2686 ] {e4df1581-c974-44b7-92ae-40bf5b49728d} TCPHandler: Code: 60. DB::Exception: Unknown table expression identifier 'mutations_r1' in scope SELECT * FROM mutations_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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000c44a97a 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4229: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283b8590 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5417: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002835acd8 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000028359104 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000028357f0d 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002921bdcc 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&) @ 0x000000002941f313 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&) @ 0x0000000029419aef 11. ./contrib/llvm-project/libcxx/include/vector:432: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000029421f5d 12. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000029344c1b 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*) @ 0x0000000029b3703b 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 16. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 20. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 21. asan_thread_start(void*) @ 0x000000000aa43059 22. ? @ 0x00007f35aab92ac3 23. ? @ 0x00007f35aac24850 2025.09.09 14:52:04.767123 [ 2761 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:52:04.823909 [ 2764 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:52:05.109787 [ 3651 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 14:52:05.531210 [ 4017 ] {5ebf1e52-b20a-425c-b782-550233ede545} executeQuery: Code: 60. DB::Exception: Table test_1.mutations_r1 does not exist. Maybe you meant system.mutations?. (UNKNOWN_TABLE) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:60480) (comment: 00652_replicated_mutations_default_database_zookeeper.sh) (in query: DROP TABLE mutations_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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x000000000ac6a006 4. ./build_docker/./src/Databases/IDatabase.cpp:39: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000027dd1c6a 5. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000286af00b 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:969: DB::DatabaseCatalog::getDatabaseAndTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000286bb62c 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x00000000291eeb31 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x00000000291ed665 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x00000000291ebd68 10. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x00000000291eb7ed 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b382fc 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 14. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 19. asan_thread_start(void*) @ 0x000000000aa43059 20. ? @ 0x00007f35aab92ac3 21. ? @ 0x00007f35aac24850 2025.09.09 14:52:05.544525 [ 4017 ] {5ebf1e52-b20a-425c-b782-550233ede545} TCPHandler: Code: 60. DB::Exception: Table test_1.mutations_r1 does not exist. Maybe you meant system.mutations?. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x000000000ac6a006 4. ./build_docker/./src/Databases/IDatabase.cpp:39: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000027dd1c6a 5. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000286af00b 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:969: DB::DatabaseCatalog::getDatabaseAndTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000286bb62c 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x00000000291eeb31 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x00000000291ed665 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x00000000291ebd68 10. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x00000000291eb7ed 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b382fc 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 14. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 19. asan_thread_start(void*) @ 0x000000000aa43059 20. ? @ 0x00007f35aab92ac3 21. ? @ 0x00007f35aac24850 2025.09.09 14:52:05.772008 [ 2775 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:52:05.826458 [ 2778 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:52:06.357605 [ 4020 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 14:52:06.429436 [ 4018 ] {0462ee8e-14d6-49bf-926e-8917f00fbbd4} executeQuery: Code: 60. DB::Exception: Table test_1.for_subquery does not exist. (UNKNOWN_TABLE) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:60530) (comment: 00652_replicated_mutations_default_database_zookeeper.sh) (in query: DROP TABLE for_subquery), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa91e9a 4. ./build_docker/./src/Databases/IDatabase.cpp:37: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000027dd1ade 5. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000286af00b 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:969: DB::DatabaseCatalog::getDatabaseAndTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000286bb62c 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x00000000291eeb31 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x00000000291ed665 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x00000000291ebd68 10. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x00000000291eb7ed 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b382fc 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 14. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 19. asan_thread_start(void*) @ 0x000000000aa43059 20. ? @ 0x00007f35aab92ac3 21. ? @ 0x00007f35aac24850 2025.09.09 14:52:06.478509 [ 4018 ] {0462ee8e-14d6-49bf-926e-8917f00fbbd4} TCPHandler: Code: 60. DB::Exception: Table test_1.for_subquery 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa91e9a 4. ./build_docker/./src/Databases/IDatabase.cpp:37: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000027dd1ade 5. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000286af00b 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:969: DB::DatabaseCatalog::getDatabaseAndTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000286bb62c 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x00000000291eeb31 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x00000000291ed665 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x00000000291ebd68 10. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x00000000291eb7ed 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b382fc 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 14. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 19. asan_thread_start(void*) @ 0x000000000aa43059 20. ? @ 0x00007f35aab92ac3 21. ? @ 0x00007f35aac24850 2025.09.09 14:52:06.775088 [ 2793 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:52:06.829448 [ 2796 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:52:07.506710 [ 4018 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 14:52:07.780364 [ 2810 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:52:07.831685 [ 2808 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:52:08.860103 [ 2835 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:52:08.860738 [ 2842 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:52:08.870350 [ 5359 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 14:52:09.091104 [ 3331 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {44b09201-5a0e-4da3-91d1-ac60ea8508c5::202509_1_15_3}: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=13, jobs=0). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af80b71 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80746 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002c765aab 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:1197: ? @ 0x000000002c7602b8 8. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x000000002c75fc2b 9. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:0: DB::MergeTreeReaderCompact::MergeTreeReaderCompact(std::shared_ptr, DB::NamesAndTypesList, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*, DB::MarkCache*, DB::MarkRanges, DB::MergeTreeReaderSettings, std::map, std::allocator>>, std::function const&, int) @ 0x000000002c7aee03 10. ./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.h:16: DB::MergeTreeReaderCompactSingleBuffer::MergeTreeReaderCompactSingleBuffer&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int&&) @ 0x000000002c5d6d21 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::MergeTreeDataPartCompact::getReader(DB::NamesAndTypesList const&, std::shared_ptr const&, DB::MarkRanges const&, std::unordered_map, std::equal_to, std::allocator>> const&, DB::UncompressedCache*, DB::MarkCache*, std::shared_ptr const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) const @ 0x000000002c5d1037 12. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:169: DB::MergeTreeSequentialSource::MergeTreeSequentialSource(DB::MergeTreeSequentialSourceType, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::vector>, std::optional, bool, bool, bool) @ 0x000000002c80c330 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:35: DB::MergeTreeSequentialSource* std::construct_at[abi:v15007] const&, std::shared_ptr&, std::shared_ptr&, std::vector>&, std::optional, bool, bool&, bool&, DB::MergeTreeSequentialSource*>(DB::MergeTreeSequentialSource*, DB::MergeTreeSequentialSourceType&, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr&, std::shared_ptr&, std::vector>&, std::optional&&, bool&&, bool&, bool&) @ 0x000000002c81320f 14. ./contrib/llvm-project/libcxx/include/__memory/allocator_traits.h:298: DB::createMergeTreeSequentialSource(DB::MergeTreeSequentialSourceType, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::vector>, std::optional, std::shared_ptr>, bool, bool, bool) @ 0x000000002c810812 15. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1136: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::createMergedStream() @ 0x000000002c3dd079 16. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() @ 0x000000002c3d6516 17. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:534: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x000000002c3e2799 18. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::execute() @ 0x000000002c3ef3fe 19. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:0: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000002cc2f4c0 20. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000002c427f28 21. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000002c429675 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7eaf0 23. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001af8a79f 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 26. asan_thread_start(void*) @ 0x000000000aa43059 27. ? @ 0x00007f35aab92ac3 28. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:52:09.092470 [ 3340 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {8dd55f4d-4394-4634-a445-9c7c9e0f4148::202509_1_31_8}: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=13, jobs=0). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af80b71 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80746 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002c765aab 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:1197: ? @ 0x000000002c7602b8 8. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x000000002c75fc2b 9. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:0: DB::MergeTreeReaderCompact::MergeTreeReaderCompact(std::shared_ptr, DB::NamesAndTypesList, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*, DB::MarkCache*, DB::MarkRanges, DB::MergeTreeReaderSettings, std::map, std::allocator>>, std::function const&, int) @ 0x000000002c7aee03 10. ./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.h:16: DB::MergeTreeReaderCompactSingleBuffer::MergeTreeReaderCompactSingleBuffer&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int&&) @ 0x000000002c5d6d21 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::MergeTreeDataPartCompact::getReader(DB::NamesAndTypesList const&, std::shared_ptr const&, DB::MarkRanges const&, std::unordered_map, std::equal_to, std::allocator>> const&, DB::UncompressedCache*, DB::MarkCache*, std::shared_ptr const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) const @ 0x000000002c5d1037 12. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:169: DB::MergeTreeSequentialSource::MergeTreeSequentialSource(DB::MergeTreeSequentialSourceType, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::vector>, std::optional, bool, bool, bool) @ 0x000000002c80c330 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:35: DB::MergeTreeSequentialSource* std::construct_at[abi:v15007] const&, std::shared_ptr&, std::shared_ptr&, std::vector>&, std::optional, bool, bool&, bool&, DB::MergeTreeSequentialSource*>(DB::MergeTreeSequentialSource*, DB::MergeTreeSequentialSourceType&, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr&, std::shared_ptr&, std::vector>&, std::optional&&, bool&&, bool&, bool&) @ 0x000000002c81320f 14. ./contrib/llvm-project/libcxx/include/__memory/allocator_traits.h:298: DB::createMergeTreeSequentialSource(DB::MergeTreeSequentialSourceType, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::vector>, std::optional, std::shared_ptr>, bool, bool, bool) @ 0x000000002c810812 15. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1136: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::createMergedStream() @ 0x000000002c3dd079 16. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() @ 0x000000002c3d6516 17. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:534: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x000000002c3e2799 18. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::execute() @ 0x000000002c3ef3fe 19. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:0: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000002cc2f4c0 20. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000002c427f28 21. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000002c429675 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7eaf0 23. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001af8a79f 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 26. asan_thread_start(void*) @ 0x000000000aa43059 27. ? @ 0x00007f35aab92ac3 28. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:52:09.863835 [ 2862 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:52:09.864050 [ 2863 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:52:10.054219 [ 4017 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 14:52:10.866912 [ 2884 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:52:10.867766 [ 2885 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:52:11.124162 [ 5360 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 14:52:11.871447 [ 2905 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:52:11.895189 [ 2903 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:52:12.267241 [ 3766 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 14:52:12.873720 [ 2918 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:52:12.897956 [ 2924 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:52:13.187760 [ 3612 ] {8afc695e-77d3-48d6-9fc9-c39e0d810dd0} executeQuery: Code: 159. DB::Exception: Timeout exceeded: elapsed 60.134963154 seconds, maximum: 60. (TIMEOUT_EXCEEDED) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:56838) (comment: 00110_external_sort.sql) (in query: SELECT number FROM (SELECT number FROM system.numbers LIMIT 10000000) ORDER BY number * 1234567890123456789 LIMIT 9999990, 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, double&&, double&&) @ 0x000000002785801a 4. ./build_docker/./src/QueryPipeline/ExecutionSpeedLimits.cpp:111: DB::ExecutionSpeedLimits::checkTimeLimit(Stopwatch const&, DB::OverflowMode) const @ 0x0000000027856784 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::finalizeExecution() @ 0x000000002d3489b5 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:132: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000002d348340 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*) @ 0x000000002d36bcf7 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 10. asan_thread_start(void*) @ 0x000000000aa43059 11. ? @ 0x00007f35aab92ac3 12. ? @ 0x00007f35aac24850 2025.09.09 14:52:13.238332 [ 5360 ] {e8067693-eb6f-41da-940c-89278a4988c0} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=13, jobs=1): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:58270) (comment: 00041_aggregating_materialized_view.sql) (in query: INSERT INTO test.visits_null SELECT CounterID, StartDate, Sign, UserID FROM test.visits;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af80b71 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80746 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002c765aab 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:1197: ? @ 0x000000002c7602b8 8. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x000000002c75fc2b 9. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:0: DB::MergeTreeReaderWide::addStream(DB::ISerialization::SubstreamPath const&, String const&) @ 0x000000002c802c31 10. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:0: void std::__function::__policy_invoker::__call_impl const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x000000002c804a95 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000027a9e455 12. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:106: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x0000000027a9ea65 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:100: DB::MergeTreeReaderWide::addStreams(DB::NameAndTypePair const&, std::shared_ptr const&) @ 0x000000002c7fe815 14. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:0: DB::MergeTreeReaderWide::MergeTreeReaderWide(std::shared_ptr, DB::NamesAndTypesList, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*, DB::MarkCache*, DB::MarkRanges, DB::MergeTreeReaderSettings, std::map, std::allocator>>, std::function const&, int) @ 0x000000002c7fdeea 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) @ 0x000000002c5eb9c6 16. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWide.cpp:43: DB::MergeTreeDataPartWide::getReader(DB::NamesAndTypesList const&, std::shared_ptr const&, DB::MarkRanges const&, std::unordered_map, std::equal_to, std::allocator>> const&, DB::UncompressedCache*, DB::MarkCache*, std::shared_ptr const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) const @ 0x000000002c5e354e 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:44: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x000000002c82a56b 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:295: DB::MergeTreeReadPoolBase::createTask(std::shared_ptr, DB::MarkRanges, DB::MergeTreeReadTask*) const @ 0x000000002de9c234 19. ./build_docker/./src/Storages/MergeTree/MergeTreeReadPoolInOrder.cpp:72: DB::MergeTreeReadPoolInOrder::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x000000002deff671 20. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectAlgorithms.cpp:17: DB::MergeTreeInOrderSelectAlgorithm::getNewTask(DB::IMergeTreeReadPool&, DB::MergeTreeReadTask*) @ 0x000000002dea3919 21. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:0: DB::MergeTreeSelectProcessor::read() @ 0x000000002c8241d2 22. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000002de6d77a 23. ./build_docker/./src/Processors/ISource.cpp:0: DB::ISource::work() @ 0x000000002d3290a1 24. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000002d34877c 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000002d34827b 28. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:57: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002d3463e7 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 31. asan_thread_start(void*) @ 0x000000000aa43059 2025.09.09 14:52:13.293053 [ 5360 ] {e8067693-eb6f-41da-940c-89278a4988c0} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=13, jobs=1): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af80b71 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80746 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002c765aab 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:1197: ? @ 0x000000002c7602b8 8. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x000000002c75fc2b 9. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:0: DB::MergeTreeReaderWide::addStream(DB::ISerialization::SubstreamPath const&, String const&) @ 0x000000002c802c31 10. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:0: void std::__function::__policy_invoker::__call_impl const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x000000002c804a95 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000027a9e455 12. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:106: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x0000000027a9ea65 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:100: DB::MergeTreeReaderWide::addStreams(DB::NameAndTypePair const&, std::shared_ptr const&) @ 0x000000002c7fe815 14. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:0: DB::MergeTreeReaderWide::MergeTreeReaderWide(std::shared_ptr, DB::NamesAndTypesList, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*, DB::MarkCache*, DB::MarkRanges, DB::MergeTreeReaderSettings, std::map, std::allocator>>, std::function const&, int) @ 0x000000002c7fdeea 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) @ 0x000000002c5eb9c6 16. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWide.cpp:43: DB::MergeTreeDataPartWide::getReader(DB::NamesAndTypesList const&, std::shared_ptr const&, DB::MarkRanges const&, std::unordered_map, std::equal_to, std::allocator>> const&, DB::UncompressedCache*, DB::MarkCache*, std::shared_ptr const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) const @ 0x000000002c5e354e 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:44: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x000000002c82a56b 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:295: DB::MergeTreeReadPoolBase::createTask(std::shared_ptr, DB::MarkRanges, DB::MergeTreeReadTask*) const @ 0x000000002de9c234 19. ./build_docker/./src/Storages/MergeTree/MergeTreeReadPoolInOrder.cpp:72: DB::MergeTreeReadPoolInOrder::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x000000002deff671 20. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectAlgorithms.cpp:17: DB::MergeTreeInOrderSelectAlgorithm::getNewTask(DB::IMergeTreeReadPool&, DB::MergeTreeReadTask*) @ 0x000000002dea3919 21. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:0: DB::MergeTreeSelectProcessor::read() @ 0x000000002c8241d2 22. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000002de6d77a 23. ./build_docker/./src/Processors/ISource.cpp:0: DB::ISource::work() @ 0x000000002d3290a1 24. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000002d34877c 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000002d34827b 28. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:57: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002d3463e7 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 31. asan_thread_start(void*) @ 0x000000000aa43059 2025.09.09 14:52:13.337233 [ 3612 ] {8afc695e-77d3-48d6-9fc9-c39e0d810dd0} TCPHandler: Code: 159. DB::Exception: Timeout exceeded: elapsed 60.134963154 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, double&&, double&&) @ 0x000000002785801a 4. ./build_docker/./src/QueryPipeline/ExecutionSpeedLimits.cpp:111: DB::ExecutionSpeedLimits::checkTimeLimit(Stopwatch const&, DB::OverflowMode) const @ 0x0000000027856784 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::finalizeExecution() @ 0x000000002d3489b5 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:132: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000002d348340 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*) @ 0x000000002d36bcf7 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 10. asan_thread_start(void*) @ 0x000000000aa43059 11. ? @ 0x00007f35aab92ac3 12. ? @ 0x00007f35aac24850 2025.09.09 14:52:13.399028 [ 2686 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 14:52:13.876665 [ 2936 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:52:13.900871 [ 2937 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:52:14.708980 [ 4018 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 14:52:14.888967 [ 2958 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:52:14.903317 [ 2959 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:52:15.892189 [ 2974 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:52:15.906447 [ 2975 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:52:16.089671 [ 4017 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 14:52:16.895415 [ 2995 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:52:16.909615 [ 2987 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:52:17.360006 [ 4022 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 14:52:17.897995 [ 3018 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:52:17.913016 [ 3021 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:52:18.529191 [ 4018 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 14:52:18.900651 [ 3035 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:52:18.915438 [ 3036 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:52:19.689541 [ 5360 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 14:52:19.903346 [ 3052 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:52:19.918052 [ 3056 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:52:20.482707 [ 5360 ] {d03ce8eb-5d38-4ea9-8837-4fa216f0e743} 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.10505.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:48884) (comment: 00149_quantiles_timing_distributed.sql) (in query: SELECT `__table1`.`CounterID` AS `CounterID`, quantileTiming(0.5)(`__table1`.`SendTiming`) AS `quantileTiming(0.5)(SendTiming)`, count() AS `count()` FROM `test`.`hits` AS `__table1` WHERE `__table1`.`SendTiming` != -1 GROUP BY `__table1`.`CounterID`), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af819ed 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80746 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d34b5ca 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000002d3486e4 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000002d34827b 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002d36bcf7 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 12. asan_thread_start(void*) @ 0x000000000aa43059 13. ? @ 0x00007f35aab92ac3 14. ? @ 0x00007f35aac24850 2025.09.09 14:52:20.498030 [ 5360 ] {d03ce8eb-5d38-4ea9-8837-4fa216f0e743} 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af819ed 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80746 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d34b5ca 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000002d3486e4 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000002d34827b 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002d36bcf7 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 12. asan_thread_start(void*) @ 0x000000000aa43059 13. ? @ 0x00007f35aab92ac3 14. ? @ 0x00007f35aac24850 2025.09.09 14:52:20.645137 [ 3651 ] {0781b7a5-6ead-4531-b1b8-7b45e2589a63} executeQuery: Code: 439. DB::Exception: Received from 127.0.0.4:9000. DB::Exception: Cannot schedule a task: failed to start the thread (threads=1, jobs=1). Stack trace: 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af819ed 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80746 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d34b5ca 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000002d3486e4 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000002d34827b 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002d36bcf7 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 12. asan_thread_start(void*) @ 0x000000000aa43059 13. ? @ 0x00007f35aab92ac3 14. ? @ 0x00007f35aac24850 : While executing Remote. (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:60574) (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. ./contrib/llvm-project/libcxx/include/string:1499: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x000000001aeb974e 3. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::Connection::receiveException() const @ 0x000000002cee6c6a 4. ./build_docker/./src/Client/Connection.cpp:0: DB::Connection::receivePacket() @ 0x000000002cef780e 5. ./build_docker/./src/Client/PacketReceiver.cpp:0: DB::PacketReceiver::Task::run(std::function, std::function) @ 0x000000002cf9767e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000278ab436 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000278aaa44 8. ./contrib/boost/boost/context/fiber_ucontext.hpp:82: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x00000000278a8394 2025.09.09 14:52:20.698850 [ 3651 ] {0781b7a5-6ead-4531-b1b8-7b45e2589a63} TCPHandler: Code: 439. DB::Exception: Received from 127.0.0.4:9000. DB::Exception: Cannot schedule a task: failed to start the thread (threads=1, jobs=1). Stack trace: 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af819ed 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80746 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d34b5ca 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000002d3486e4 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000002d34827b 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002d36bcf7 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 12. asan_thread_start(void*) @ 0x000000000aa43059 13. ? @ 0x00007f35aab92ac3 14. ? @ 0x00007f35aac24850 : 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. ./contrib/llvm-project/libcxx/include/string:1499: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x000000001aeb974e 3. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::Connection::receiveException() const @ 0x000000002cee6c6a 4. ./build_docker/./src/Client/Connection.cpp:0: DB::Connection::receivePacket() @ 0x000000002cef780e 5. ./build_docker/./src/Client/PacketReceiver.cpp:0: DB::PacketReceiver::Task::run(std::function, std::function) @ 0x000000002cf9767e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000278ab436 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000278aaa44 8. ./contrib/boost/boost/context/fiber_ucontext.hpp:82: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x00000000278a8394 2025.09.09 14:52:20.756578 [ 3766 ] {} ServerErrorHandler: Code: 210. DB::NetException: Connection reset by peer, while reading from socket (peer: [::ffff:127.0.0.1]:37926, local: [::ffff:127.0.0.10]: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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 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&&) @ 0x000000001b0b7a5f 3. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:83: DB::ReadBufferFromPocoSocketBase::socketReceiveBytesImpl(char*, unsigned long) @ 0x000000001b0b6042 4. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:107: DB::ReadBufferFromPocoSocketBase::nextImpl() @ 0x000000001b0b6b84 5. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:103: DB::ReadBufferFromPocoSocketChunked::nextImpl() @ 0x000000002cf045f6 6. DB::ReadBuffer::next() @ 0x000000000b528aeb 7. ./build_docker/./src/Server/TCPHandler.cpp:383: DB::TCPHandler::runImpl() @ 0x000000002d174fd3 8. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 12. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 13. asan_thread_start(void*) @ 0x000000000aa43059 14. ? @ 0x00007f35aab92ac3 15. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:52:20.758933 [ 3640 ] {} ServerErrorHandler: Code: 210. DB::NetException: Connection reset by peer, while reading from socket (peer: [::ffff:127.0.0.1]:50318, local: [::ffff:127.0.0.8]: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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 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&&) @ 0x000000001b0b7a5f 3. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:83: DB::ReadBufferFromPocoSocketBase::socketReceiveBytesImpl(char*, unsigned long) @ 0x000000001b0b6042 4. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:107: DB::ReadBufferFromPocoSocketBase::nextImpl() @ 0x000000001b0b6b84 5. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:103: DB::ReadBufferFromPocoSocketChunked::nextImpl() @ 0x000000002cf045f6 6. DB::ReadBuffer::next() @ 0x000000000b528aeb 7. ./build_docker/./src/Server/TCPHandler.cpp:383: DB::TCPHandler::runImpl() @ 0x000000002d174fd3 8. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 12. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 13. asan_thread_start(void*) @ 0x000000000aa43059 14. ? @ 0x00007f35aab92ac3 15. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:52:20.851562 [ 3722 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 14:52:20.906024 [ 3075 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:52:20.920760 [ 3076 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:52:20.991517 [ 4023 ] {9b2cd1d0-df17-45f1-b79c-fcfe5c2220e1} executeQuery: Code: 57. DB::Exception: Table test_cqj06wml.parsing_with_names already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:41738) (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa91e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1558: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291bc5ff 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291ac835 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000291c3415 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b382fc 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 15. asan_thread_start(void*) @ 0x000000000aa43059 16. ? @ 0x00007f35aab92ac3 17. ? @ 0x00007f35aac24850 2025.09.09 14:52:21.011156 [ 4023 ] {9b2cd1d0-df17-45f1-b79c-fcfe5c2220e1} TCPHandler: Code: 57. DB::Exception: Table test_cqj06wml.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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa91e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1558: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291bc5ff 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291ac835 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000291c3415 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b382fc 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 15. asan_thread_start(void*) @ 0x000000000aa43059 16. ? @ 0x00007f35aab92ac3 17. ? @ 0x00007f35aac24850 2025.09.09 14:52:21.908021 [ 3090 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:52:21.932413 [ 3092 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:52:21.970700 [ 3722 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 14:52:22.910100 [ 3111 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:52:22.937118 [ 3114 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:52:22.964802 [ 3604 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 14:52:23.912746 [ 3138 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:52:23.939906 [ 3141 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:52:24.083609 [ 3722 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 14:52:24.916980 [ 3154 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:52:24.943088 [ 3156 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:52:25.374358 [ 3640 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 14:52:25.919284 [ 3182 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:52:25.955151 [ 3183 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:52:26.685614 [ 3640 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 14:52:26.922591 [ 3199 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:52:26.958031 [ 3200 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:52:27.925370 [ 3221 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:52:27.960495 [ 3224 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:52:28.040230 [ 3766 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 14:52:28.405262 [ 4016 ] {65aa41a4-4399-4415-8a4e-e31173569f13} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=757, jobs=726). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45712) (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af872f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af7b2d1 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af7c3f3 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d36920d 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000002d369e5f 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processOrdinaryQuery() @ 0x000000002d18af7b 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d17644a 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 15. asan_thread_start(void*) @ 0x000000000aa43059 16. ? @ 0x00007f35aab92ac3 17. ? @ 0x00007f35aac24850 2025.09.09 14:52:28.440991 [ 4016 ] {65aa41a4-4399-4415-8a4e-e31173569f13} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=757, jobs=726). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af872f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af7b2d1 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af7c3f3 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d36920d 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000002d369e5f 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processOrdinaryQuery() @ 0x000000002d18af7b 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d17644a 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 15. asan_thread_start(void*) @ 0x000000000aa43059 16. ? @ 0x00007f35aab92ac3 17. ? @ 0x00007f35aac24850 2025.09.09 14:52:28.929580 [ 3242 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:52:28.968269 [ 2732 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:52:29.290561 [ 4018 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 14:52:29.932444 [ 2762 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:52:29.974676 [ 2740 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:52:30.417269 [ 4022 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 14:52:30.935799 [ 2775 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:52:30.977310 [ 2778 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:52:31.580773 [ 3640 ] {2de6c13d-7bf2-4c10-938b-ba181c250d3c} executeQuery: Code: 48. DB::Exception: Truncate is not supported by storage Null. (NOT_IMPLEMENTED) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45822) (comment: 00041_aggregating_materialized_view.sql) (in query: DROP TABLE IF EXISTS test.visits_null;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::IStorage::truncate(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, DB::TableExclusiveLockHolder&) @ 0x00000000260e9270 4. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:279: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x00000000291f066f 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x00000000291ed665 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x00000000291ebd68 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x00000000291eb7ed 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b382fc 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 11. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 15. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 16. asan_thread_start(void*) @ 0x000000000aa43059 17. ? @ 0x00007f35aab92ac3 18. ? @ 0x00007f35aac24850 2025.09.09 14:52:31.589274 [ 3640 ] {2de6c13d-7bf2-4c10-938b-ba181c250d3c} 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::IStorage::truncate(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, DB::TableExclusiveLockHolder&) @ 0x00000000260e9270 4. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:279: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x00000000291f066f 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x00000000291ed665 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x00000000291ebd68 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x00000000291eb7ed 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b382fc 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 11. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 15. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 16. asan_thread_start(void*) @ 0x000000000aa43059 17. ? @ 0x00007f35aab92ac3 18. ? @ 0x00007f35aac24850 2025.09.09 14:52:31.753901 [ 5359 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 14:52:31.938732 [ 2795 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:52:31.980208 [ 2800 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:52:32.755942 [ 3331 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {106d09da-5a03-4cbf-a443-a9d7490e42ad::202509_1_31_6}: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=13, jobs=0). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af80b71 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80746 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002c765aab 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:1197: ? @ 0x000000002c7602b8 8. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x000000002c75fc2b 9. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:0: DB::MergeTreeReaderCompact::MergeTreeReaderCompact(std::shared_ptr, DB::NamesAndTypesList, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*, DB::MarkCache*, DB::MarkRanges, DB::MergeTreeReaderSettings, std::map, std::allocator>>, std::function const&, int) @ 0x000000002c7aee03 10. ./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.h:16: DB::MergeTreeReaderCompactSingleBuffer::MergeTreeReaderCompactSingleBuffer&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int&&) @ 0x000000002c5d6d21 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::MergeTreeDataPartCompact::getReader(DB::NamesAndTypesList const&, std::shared_ptr const&, DB::MarkRanges const&, std::unordered_map, std::equal_to, std::allocator>> const&, DB::UncompressedCache*, DB::MarkCache*, std::shared_ptr const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) const @ 0x000000002c5d1037 12. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:169: DB::MergeTreeSequentialSource::MergeTreeSequentialSource(DB::MergeTreeSequentialSourceType, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::vector>, std::optional, bool, bool, bool) @ 0x000000002c80c330 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:35: DB::MergeTreeSequentialSource* std::construct_at[abi:v15007] const&, std::shared_ptr&, std::shared_ptr&, std::vector>&, std::optional, bool, bool&, bool&, DB::MergeTreeSequentialSource*>(DB::MergeTreeSequentialSource*, DB::MergeTreeSequentialSourceType&, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr&, std::shared_ptr&, std::vector>&, std::optional&&, bool&&, bool&, bool&) @ 0x000000002c81320f 14. ./contrib/llvm-project/libcxx/include/__memory/allocator_traits.h:298: DB::createMergeTreeSequentialSource(DB::MergeTreeSequentialSourceType, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::vector>, std::optional, std::shared_ptr>, bool, bool, bool) @ 0x000000002c810812 15. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1136: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::createMergedStream() @ 0x000000002c3dd079 16. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() @ 0x000000002c3d6516 17. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:534: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x000000002c3e2799 18. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::execute() @ 0x000000002c3ef3fe 19. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:0: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000002cc2f4c0 20. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000002c427f28 21. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000002c429675 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7eaf0 23. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001af8a79f 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 26. asan_thread_start(void*) @ 0x000000000aa43059 27. ? @ 0x00007f35aab92ac3 28. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:52:32.945501 [ 2823 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:52:32.982539 [ 2824 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:52:33.030627 [ 5359 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 14:52:33.948962 [ 2835 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:52:33.987179 [ 2842 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:52:34.407027 [ 4022 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 14:52:35.024629 [ 2864 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:52:35.026372 [ 2866 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:52:35.860515 [ 5359 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 14:52:36.027718 [ 2886 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:52:36.029129 [ 2888 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:52:36.937205 [ 4023 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 14:52:37.107436 [ 2922 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:52:37.195828 [ 2912 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:52:37.745739 [ 4022 ] {9ac8a9a6-a6c2-4201-9850-92bee145ee17} executeQuery: Code: 80. DB::Exception: DETACH TABLE is not allowed for Replicated databases. Use DETACH TABLE PERMANENTLY or SYSTEM RESTART REPLICA or set database_replicated_always_detach_permanently to 1. (INCORRECT_QUERY) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45934) (comment: 00152_insert_different_granularity.sql) (in query: -- We have removed testing of OPTIMIZE because it's too heavy on very slow builds (debug + coverage + thread fuzzer with sleeps) -- OPTIMIZE TABLE fixed_granularity_table FINAL; -- and even after optimize DETACH TABLE fixed_granularity_table;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aac868e 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:979: DB::DatabaseReplicated::checkQueryValid(std::shared_ptr const&, std::shared_ptr) const @ 0x0000000027d5ea92 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:999: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000027d5f0de 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x00000000291f029c 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x00000000291ed665 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x00000000291ebd68 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x00000000291eb7ed 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b382fc 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 13. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 18. asan_thread_start(void*) @ 0x000000000aa43059 19. ? @ 0x00007f35aab92ac3 20. ? @ 0x00007f35aac24850 2025.09.09 14:52:37.757761 [ 4022 ] {9ac8a9a6-a6c2-4201-9850-92bee145ee17} TCPHandler: Code: 80. DB::Exception: DETACH TABLE is not allowed for Replicated databases. Use DETACH TABLE PERMANENTLY or SYSTEM RESTART REPLICA or set database_replicated_always_detach_permanently to 1. (INCORRECT_QUERY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aac868e 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:979: DB::DatabaseReplicated::checkQueryValid(std::shared_ptr const&, std::shared_ptr) const @ 0x0000000027d5ea92 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:999: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000027d5f0de 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x00000000291f029c 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x00000000291ed665 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x00000000291ebd68 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x00000000291eb7ed 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b382fc 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 13. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 18. asan_thread_start(void*) @ 0x000000000aa43059 19. ? @ 0x00007f35aab92ac3 20. ? @ 0x00007f35aac24850 2025.09.09 14:52:38.018243 [ 4022 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 14:52:38.117789 [ 2926 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:52:38.197919 [ 2928 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:52:38.840324 [ 4022 ] {204023b8-fb39-46b5-90f7-119ce2f9f089} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=3, jobs=3). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:53316) (comment: 00021_2_select_with_in.sql) (in query: select sum(Sign) from test.visits where CounterID in (942285, 577322);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af80b71 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af82f33 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002c64fc80 7. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1723: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr, unsigned long, std::shared_ptr, std::equal_to, std::allocator>>>, DB::MergeTreeData const&, std::vector> const&, std::shared_ptr, std::optional&, bool) @ 0x000000002de379fd 8. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1437: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000002de3554f 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:0: DB::ReadFromMergeTree::getAnalysisResult() const @ 0x000000002de41345 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:2022: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000002de4404c 11. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000002ddb933c 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000002ddff11e 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000002942117f 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x00000000294209e7 15. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b382fc 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 18. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 22. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 14:52:38.845024 [ 4022 ] {204023b8-fb39-46b5-90f7-119ce2f9f089} 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af80b71 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af82f33 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002c64fc80 7. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1723: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr, unsigned long, std::shared_ptr, std::equal_to, std::allocator>>>, DB::MergeTreeData const&, std::vector> const&, std::shared_ptr, std::optional&, bool) @ 0x000000002de379fd 8. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1437: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000002de3554f 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:0: DB::ReadFromMergeTree::getAnalysisResult() const @ 0x000000002de41345 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:2022: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000002de4404c 11. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000002ddb933c 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000002ddff11e 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000002942117f 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x00000000294209e7 15. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b382fc 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 18. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 22. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 14:52:39.120584 [ 2950 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:52:39.122371 [ 4022 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 14:52:39.206607 [ 2948 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:52:39.221019 [ 4016 ] {7d5fd297-b5b6-44da-900e-23186c94671f} executeQuery: Code: 48. DB::Exception: Truncate is not supported by storage Merge. (NOT_IMPLEMENTED) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45738) (comment: 02763_row_policy_storage_merge_alias.gen.sql) (in query: DROP TABLE 02763_a_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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::IStorage::truncate(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, DB::TableExclusiveLockHolder&) @ 0x00000000260e9270 4. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:279: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x00000000291f066f 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x00000000291ed665 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x00000000291ebd68 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x00000000291eb7ed 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b382fc 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 11. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 15. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 16. asan_thread_start(void*) @ 0x000000000aa43059 17. ? @ 0x00007f35aab92ac3 18. ? @ 0x00007f35aac24850 2025.09.09 14:52:39.225269 [ 4016 ] {7d5fd297-b5b6-44da-900e-23186c94671f} 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::IStorage::truncate(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, DB::TableExclusiveLockHolder&) @ 0x00000000260e9270 4. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:279: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x00000000291f066f 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x00000000291ed665 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x00000000291ebd68 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x00000000291eb7ed 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b382fc 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 11. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 15. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 16. asan_thread_start(void*) @ 0x000000000aa43059 17. ? @ 0x00007f35aab92ac3 18. ? @ 0x00007f35aac24850 2025.09.09 14:52:40.122738 [ 2969 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:52:40.195552 [ 4023 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 14:52:40.217205 [ 2975 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:52:41.124715 [ 2990 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:52:41.219335 [ 2997 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:52:41.248252 [ 3722 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 14:52:41.555926 [ 2996 ] {} 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af819ed 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80746 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000263a174e 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000286c6b9c 8. ./contrib/llvm-project/libcxx/include/vector:590: DB::DatabaseCatalog::dropTableDataTask() @ 0x00000000286c7466 9. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 11. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 14. asan_thread_start(void*) @ 0x000000000aa43059 15. ? @ 0x00007f35aab92ac3 16. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:52:42.127627 [ 3013 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:52:42.222502 [ 3016 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:52:42.499268 [ 2688 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 14:52:43.130584 [ 3032 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:52:43.225698 [ 3033 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:52:43.818321 [ 3722 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 14:52:44.133870 [ 3049 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:52:44.235795 [ 3051 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:52:45.085652 [ 2688 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 14:52:45.136141 [ 3064 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:52:45.241302 [ 3067 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:52:46.139215 [ 3086 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:52:46.223706 [ 2688 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 14:52:46.246850 [ 3090 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:52:47.141362 [ 3108 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:52:47.250918 [ 3112 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:52:47.306245 [ 3722 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 14:52:48.143511 [ 3131 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:52:48.253293 [ 3135 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:52:48.366535 [ 2688 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 14:52:49.102351 [ 3722 ] {e20c6806-f705-4bb5-8262-b3aa96039ea1} executeQuery: Code: 57. DB::Exception: Table test_9.parsing_with_names already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:57236) (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa91e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1558: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291bc5ff 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291ac835 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000291c3415 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b382fc 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 15. asan_thread_start(void*) @ 0x000000000aa43059 16. ? @ 0x00007f35aab92ac3 17. ? @ 0x00007f35aac24850 2025.09.09 14:52:49.117848 [ 3722 ] {e20c6806-f705-4bb5-8262-b3aa96039ea1} TCPHandler: Code: 57. DB::Exception: Table test_9.parsing_with_names already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa91e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1558: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291bc5ff 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291ac835 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000291c3415 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b382fc 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 15. asan_thread_start(void*) @ 0x000000000aa43059 16. ? @ 0x00007f35aab92ac3 17. ? @ 0x00007f35aac24850 2025.09.09 14:52:49.145948 [ 3157 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:52:49.255493 [ 3162 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:52:49.404780 [ 3722 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 14:52:49.601678 [ 2688 ] {10dd4354-9b74-414b-b97e-8ec01371d4a9} executeQuery: Code: 57. DB::Exception: Table test_cqj06wml.parsing_with_names already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:57260) (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa91e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1558: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291bc5ff 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291ac835 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000291c3415 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b382fc 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 15. asan_thread_start(void*) @ 0x000000000aa43059 16. ? @ 0x00007f35aab92ac3 17. ? @ 0x00007f35aac24850 2025.09.09 14:52:49.614316 [ 2688 ] {10dd4354-9b74-414b-b97e-8ec01371d4a9} TCPHandler: Code: 57. DB::Exception: Table test_cqj06wml.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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa91e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1558: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291bc5ff 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291ac835 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000291c3415 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b382fc 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 15. asan_thread_start(void*) @ 0x000000000aa43059 16. ? @ 0x00007f35aab92ac3 17. ? @ 0x00007f35aac24850 2025.09.09 14:52:50.151595 [ 3176 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:52:50.257502 [ 3181 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:52:50.501054 [ 4025 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 14:52:51.158404 [ 3196 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:52:51.259753 [ 3198 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:52:51.452009 [ 4020 ] {} ServerErrorHandler: Code: 210. DB::NetException: Connection reset by peer, while reading from socket (peer: [::ffff:127.0.0.1]:34646, local: [::ffff:127.0.0.6]:9000). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 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&&) @ 0x000000001b0b7a5f 3. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:83: DB::ReadBufferFromPocoSocketBase::socketReceiveBytesImpl(char*, unsigned long) @ 0x000000001b0b6042 4. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:107: DB::ReadBufferFromPocoSocketBase::nextImpl() @ 0x000000001b0b6b84 5. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:103: DB::ReadBufferFromPocoSocketChunked::nextImpl() @ 0x000000002cf045f6 6. DB::ReadBuffer::next() @ 0x000000000b528aeb 7. ./build_docker/./src/Server/TCPHandler.cpp:383: DB::TCPHandler::runImpl() @ 0x000000002d174fd3 8. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 12. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 13. asan_thread_start(void*) @ 0x000000000aa43059 14. ? @ 0x00007f35aab92ac3 15. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:52:51.457231 [ 2688 ] {a7a09930-1679-4f51-9ea1-1f19cff23bee} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=30, jobs=30). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:57342) (comment: 01825_new_type_json_ghdata_insert_select.sh) (in query: SELECT (SELECT mapSort(groupUniqArrayMap(JSONAllPathsWithTypes(data))), sum(cityHash64(toString(data))) FROM ghdata_2_from_string) = (SELECT mapSort(groupUniqArrayMap(JSONAllPathsWithTypes(data))), sum(cityHash64(toString(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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af80b71 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80746 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d34b5ca 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:306: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349fbb 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:381: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000002d34bd35 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7eaf0 10. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001af8a79f 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 13. asan_thread_start(void*) @ 0x000000000aa43059 14. ? @ 0x00007f35aab92ac3 15. ? @ 0x00007f35aac24850 2025.09.09 14:52:51.460379 [ 2686 ] {} ServerErrorHandler: Code: 210. DB::NetException: Connection reset by peer, while reading from socket (peer: [::ffff:127.0.0.1]:38784, local: [::ffff:127.0.0.1]:9000). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 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&&) @ 0x000000001b0b7a5f 3. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:83: DB::ReadBufferFromPocoSocketBase::socketReceiveBytesImpl(char*, unsigned long) @ 0x000000001b0b6042 4. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:107: DB::ReadBufferFromPocoSocketBase::nextImpl() @ 0x000000001b0b6b84 5. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:103: DB::ReadBufferFromPocoSocketChunked::nextImpl() @ 0x000000002cf045f6 6. DB::ReadBuffer::next() @ 0x000000000b528aeb 7. ./build_docker/./src/Server/TCPHandler.cpp:383: DB::TCPHandler::runImpl() @ 0x000000002d174fd3 8. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 12. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 13. asan_thread_start(void*) @ 0x000000000aa43059 14. ? @ 0x00007f35aab92ac3 15. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:52:51.522320 [ 2688 ] {a7a09930-1679-4f51-9ea1-1f19cff23bee} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=30, jobs=30). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af80b71 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80746 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d34b5ca 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:306: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349fbb 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:381: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000002d34bd35 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7eaf0 10. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001af8a79f 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 13. asan_thread_start(void*) @ 0x000000000aa43059 14. ? @ 0x00007f35aab92ac3 15. ? @ 0x00007f35aac24850 2025.09.09 14:52:51.523227 [ 4025 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 14:52:51.563278 [ 3640 ] {6eb7faf3-f670-4e72-9a32-807391236910} executeQuery: Code: 210. DB::NetException: Connection reset by peer, while writing to socket ([::ffff:127.0.0.10]:9000 -> [::ffff:127.0.0.1]:54314). (NETWORK_ERROR) (version 24.8.14.10505.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:54314) (comment: 01825_new_type_json_ghdata_insert_select.sh) (in query: SELECT mapSort(groupUniqArrayMap(JSONAllPathsWithTypes(`__table1`.`data`))) AS `mapSort(groupUniqArrayMap(JSONAllPathsWithTypes(data)))`, sum(cityHash64(toString(`__table1`.`data`))) AS `sum(cityHash64(toString(data)))` FROM `test_3`.`ghdata_2_from_string` AS `__table1`), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 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&&) @ 0x000000001b0b7a5f 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:158: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000001b0bab02 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:201: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000002cf09bf7 5. ./src/IO/WriteBuffer.h:66: DB::TCPHandler::sendEndOfStream() @ 0x000000002d18e36e 6. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d176757 7. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 11. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 12. asan_thread_start(void*) @ 0x000000000aa43059 13. ? @ 0x00007f35aab92ac3 14. ? @ 0x00007f35aac24850 2025.09.09 14:52:51.706271 [ 3640 ] {6eb7faf3-f670-4e72-9a32-807391236910} TCPHandler: Can't send logs to client: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::ffff:127.0.0.10]:9000 -> [::ffff:127.0.0.1]:54314). (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 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&&) @ 0x000000001b0b7a5f 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:169: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000001b0bada2 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:201: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000002cf09bf7 5. ./src/IO/WriteBuffer.h:66: DB::TCPHandler::sendLogData(DB::Block const&) @ 0x000000002d1a9beb 6. ./contrib/llvm-project/libcxx/include/__hash_table:1473: DB::TCPHandler::sendLogs() @ 0x000000002d18db59 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d176902 8. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 12. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 13. asan_thread_start(void*) @ 0x000000000aa43059 14. ? @ 0x00007f35aab92ac3 15. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:52:51.710512 [ 3640 ] {6eb7faf3-f670-4e72-9a32-807391236910} TCPHandler: Code: 210. DB::NetException: Connection reset by peer, while writing to socket ([::ffff:127.0.0.10]:9000 -> [::ffff:127.0.0.1]:54314). (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 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&&) @ 0x000000001b0b7a5f 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:158: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000001b0bab02 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:201: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000002cf09bf7 5. ./src/IO/WriteBuffer.h:66: DB::TCPHandler::sendEndOfStream() @ 0x000000002d18e36e 6. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d176757 7. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 11. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 12. asan_thread_start(void*) @ 0x000000000aa43059 13. ? @ 0x00007f35aab92ac3 14. ? @ 0x00007f35aac24850 2025.09.09 14:52:51.715609 [ 3640 ] {6eb7faf3-f670-4e72-9a32-807391236910} TCPHandler: Client has gone away. 2025.09.09 14:52:52.160605 [ 3214 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:52:52.272086 [ 3220 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:52:52.605616 [ 3640 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 14:52:53.162708 [ 3234 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:52:53.276940 [ 3236 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:52:53.657816 [ 4016 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 14:52:53.777784 [ 4020 ] {9ac2c2e7-938f-46fb-9cf4-5deadb5c28d8} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=1, jobs=1). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:57434) (comment: 00077_log_tinylog_stripelog.sql) (in query: CHECK TABLE test.hits_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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af80b71 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80746 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d34b5ca 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000002d3486e4 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000002d34827b 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002d36bcf7 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 12. asan_thread_start(void*) @ 0x000000000aa43059 13. ? @ 0x00007f35aab92ac3 14. ? @ 0x00007f35aac24850 2025.09.09 14:52:53.802566 [ 4020 ] {9ac2c2e7-938f-46fb-9cf4-5deadb5c28d8} 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af80b71 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80746 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d34b5ca 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000002d3486e4 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000002d34827b 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002d36bcf7 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 12. asan_thread_start(void*) @ 0x000000000aa43059 13. ? @ 0x00007f35aab92ac3 14. ? @ 0x00007f35aac24850 2025.09.09 14:52:54.164738 [ 2736 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:52:54.285008 [ 2757 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:52:54.549406 [ 4020 ] {962edaf5-f8d3-4823-8784-fc408c62df12} executeQuery: Code: 57. DB::Exception: Table test_9.parsing_with_names already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:57488) (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa91e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1558: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291bc5ff 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291ac835 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000291c3415 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b382fc 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 15. asan_thread_start(void*) @ 0x000000000aa43059 16. ? @ 0x00007f35aab92ac3 17. ? @ 0x00007f35aac24850 2025.09.09 14:52:54.559752 [ 4020 ] {962edaf5-f8d3-4823-8784-fc408c62df12} TCPHandler: Code: 57. DB::Exception: Table test_9.parsing_with_names already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa91e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1558: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291bc5ff 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291ac835 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000291c3415 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b382fc 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 15. asan_thread_start(void*) @ 0x000000000aa43059 16. ? @ 0x00007f35aab92ac3 17. ? @ 0x00007f35aac24850 2025.09.09 14:52:54.626806 [ 4025 ] {15cbf182-eb21-4d82-b486-d5f412c8a410} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 2nd argument 'input' to function 'encrypt'. Expected: plaintext, got: Array(Nullable(Int16)): In scope SELECT encrypt('aes-128-ecb', '[HIDDEN]'). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:57486) (comment: 01667_aes_args_check.sql) (in query: SELECT encrypt('aes-128-ecb', '[HIDDEN]')), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 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&&) @ 0x000000000aaec6f5 4. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000000aae6b1a 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000000aae5e2a 6. DB::FunctionEncrypt::getReturnTypeImpl(std::vector> const&) const @ 0x000000000f221507 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000ccd376e 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000ccd3176 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000ccd4343 10. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000028399ff0 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000028367bce 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028366290 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283b62c9 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002835ae03 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000028359104 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000028357f0d 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002921bdcc 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&) @ 0x000000002941f313 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&) @ 0x0000000029419aef 20. ./contrib/llvm-project/libcxx/include/vector:432: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000029421f5d 21. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000029344c1b 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*) @ 0x0000000029b3703b 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 25. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 29. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 30. asan_thread_start(void*) @ 0x000000000aa43059 31. ? @ 0x00007f35aab92ac3 2025.09.09 14:52:54.632859 [ 4025 ] {15cbf182-eb21-4d82-b486-d5f412c8a410} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 2nd argument 'input' to function 'encrypt'. Expected: plaintext, got: Array(Nullable(Int16)): In scope SELECT encrypt('aes-128-ecb', '[HIDDEN]'). (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 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&&) @ 0x000000000aaec6f5 4. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000000aae6b1a 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000000aae5e2a 6. DB::FunctionEncrypt::getReturnTypeImpl(std::vector> const&) const @ 0x000000000f221507 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000ccd376e 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000ccd3176 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000ccd4343 10. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000028399ff0 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000028367bce 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028366290 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283b62c9 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002835ae03 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000028359104 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000028357f0d 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002921bdcc 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&) @ 0x000000002941f313 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&) @ 0x0000000029419aef 20. ./contrib/llvm-project/libcxx/include/vector:432: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000029421f5d 21. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000029344c1b 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*) @ 0x0000000029b3703b 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 25. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 29. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 30. asan_thread_start(void*) @ 0x000000000aa43059 31. ? @ 0x00007f35aab92ac3 2025.09.09 14:52:54.706008 [ 4016 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 14:52:55.210008 [ 2772 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:52:55.241596 [ 3330 ] {69e574b3-ceb7-4514-b328-236b948514f3::all_2_2_0_3} MutatePlainMergeTreeTask: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=10, jobs=10). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:52:55.246137 [ 3330 ] {69e574b3-ceb7-4514-b328-236b948514f3::all_2_2_0_3} virtual bool DB::MutatePlainMergeTreeTask::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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af819ed 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80746 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d34b5ca 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000002d3486e4 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000002d34827b 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002d36bcf7 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 12. asan_thread_start(void*) @ 0x000000000aa43059 13. ? @ 0x00007f35aab92ac3 14. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:52:55.289845 [ 2775 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:52:55.372467 [ 3640 ] {da207a18-d50f-4bf1-b8f2-fafe3290449b} executeQuery: Code: 341. DB::Exception: Exception happened during execution of mutation 'mutation_3.txt' with part 'all_2_2_0' reason: 'Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=10, jobs=10). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.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.10505.altinitytest (altinity build)) (from [::1]:57448) (comment: 01358_mutation_delete_null_rows.sql) (in query: ALTER TABLE mutation_delete_null_rows DELETE WHERE UserID = 0 SETTINGS mutations_sync=1;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&&, String&, String&) @ 0x000000002c76d4c6 4. ./build_docker/./src/Storages/MergeTree/MergeTreeMutationStatus.cpp:26: DB::checkMutationStatus(std::optional&, std::set, std::allocator> const&) @ 0x000000002c76d210 5. ./build_docker/./src/Storages/StorageMergeTree.cpp:0: DB::StorageMergeTree::waitForMutation(long, String const&, bool) @ 0x000000002cbbc805 6. ./contrib/llvm-project/libcxx/include/string:1499: DB::StorageMergeTree::mutate(DB::MutationCommands const&, std::shared_ptr) @ 0x000000002cbbe409 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000029174a1c 8. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x0000000029170711 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b382fc 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 14:52:55.445043 [ 3640 ] {da207a18-d50f-4bf1-b8f2-fafe3290449b} TCPHandler: Code: 341. DB::Exception: Exception happened during execution of mutation 'mutation_3.txt' with part 'all_2_2_0' reason: 'Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=10, jobs=10). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&&, String&, String&) @ 0x000000002c76d4c6 4. ./build_docker/./src/Storages/MergeTree/MergeTreeMutationStatus.cpp:26: DB::checkMutationStatus(std::optional&, std::set, std::allocator> const&) @ 0x000000002c76d210 5. ./build_docker/./src/Storages/StorageMergeTree.cpp:0: DB::StorageMergeTree::waitForMutation(long, String const&, bool) @ 0x000000002cbbc805 6. ./contrib/llvm-project/libcxx/include/string:1499: DB::StorageMergeTree::mutate(DB::MutationCommands const&, std::shared_ptr) @ 0x000000002cbbe409 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000029174a1c 8. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x0000000029170711 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b382fc 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 14:52:55.725419 [ 4016 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 14:52:56.212076 [ 2789 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:52:56.292114 [ 2790 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:52:56.784266 [ 5360 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 14:52:57.214229 [ 2812 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:52:57.294267 [ 2809 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:52:57.841460 [ 5360 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 14:52:57.941714 [ 4020 ] {3c68e714-f52c-49ef-b1da-633b397375a8} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=13, jobs=1): While executing MergeTreeSelect(pool: ReadPool, algorithm: Thread). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:57494) (comment: 00024_random_counters.sql) (in query: SELECT uniq(UserID), sum(Sign) FROM test.visits WHERE CounterID = 27855803;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af80b71 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80746 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002c765aab 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:1197: ? @ 0x000000002c7602b8 8. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x000000002c75fc2b 9. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:0: DB::MergeTreeReaderWide::addStream(DB::ISerialization::SubstreamPath const&, String const&) @ 0x000000002c802c31 10. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:0: void std::__function::__policy_invoker::__call_impl const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x000000002c804a95 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000027a9e455 12. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:106: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x0000000027a9ea65 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:100: DB::MergeTreeReaderWide::addStreams(DB::NameAndTypePair const&, std::shared_ptr const&) @ 0x000000002c7fe815 14. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:0: DB::MergeTreeReaderWide::MergeTreeReaderWide(std::shared_ptr, DB::NamesAndTypesList, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*, DB::MarkCache*, DB::MarkRanges, DB::MergeTreeReaderSettings, std::map, std::allocator>>, std::function const&, int) @ 0x000000002c7fdeea 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) @ 0x000000002c5eb9c6 16. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWide.cpp:43: DB::MergeTreeDataPartWide::getReader(DB::NamesAndTypesList const&, std::shared_ptr const&, DB::MarkRanges const&, std::unordered_map, std::equal_to, std::allocator>> const&, DB::UncompressedCache*, DB::MarkCache*, std::shared_ptr const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) const @ 0x000000002c5e354e 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:44: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x000000002c82acda 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:295: DB::MergeTreeReadPoolBase::createTask(std::shared_ptr, DB::MarkRanges, DB::MergeTreeReadTask*) const @ 0x000000002de9c5f2 19. ./build_docker/./src/Storages/MergeTree/MergeTreeReadPool.cpp:144: DB::MergeTreeReadPool::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x000000002def1bcc 20. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:0: DB::MergeTreeSelectProcessor::read() @ 0x000000002c8241d2 21. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000002de6d77a 22. ./build_docker/./src/Processors/ISource.cpp:0: DB::ISource::work() @ 0x000000002d3290a1 23. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:381: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000002d34bd35 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7eaf0 27. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001af8a79f 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 30. asan_thread_start(void*) @ 0x000000000aa43059 31. ? @ 0x00007f35aab92ac3 2025.09.09 14:52:57.966629 [ 4020 ] {3c68e714-f52c-49ef-b1da-633b397375a8} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=13, 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af80b71 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80746 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002c765aab 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:1197: ? @ 0x000000002c7602b8 8. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x000000002c75fc2b 9. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:0: DB::MergeTreeReaderWide::addStream(DB::ISerialization::SubstreamPath const&, String const&) @ 0x000000002c802c31 10. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:0: void std::__function::__policy_invoker::__call_impl const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x000000002c804a95 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000027a9e455 12. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:106: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x0000000027a9ea65 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:100: DB::MergeTreeReaderWide::addStreams(DB::NameAndTypePair const&, std::shared_ptr const&) @ 0x000000002c7fe815 14. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:0: DB::MergeTreeReaderWide::MergeTreeReaderWide(std::shared_ptr, DB::NamesAndTypesList, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*, DB::MarkCache*, DB::MarkRanges, DB::MergeTreeReaderSettings, std::map, std::allocator>>, std::function const&, int) @ 0x000000002c7fdeea 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) @ 0x000000002c5eb9c6 16. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWide.cpp:43: DB::MergeTreeDataPartWide::getReader(DB::NamesAndTypesList const&, std::shared_ptr const&, DB::MarkRanges const&, std::unordered_map, std::equal_to, std::allocator>> const&, DB::UncompressedCache*, DB::MarkCache*, std::shared_ptr const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) const @ 0x000000002c5e354e 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:44: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x000000002c82acda 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:295: DB::MergeTreeReadPoolBase::createTask(std::shared_ptr, DB::MarkRanges, DB::MergeTreeReadTask*) const @ 0x000000002de9c5f2 19. ./build_docker/./src/Storages/MergeTree/MergeTreeReadPool.cpp:144: DB::MergeTreeReadPool::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x000000002def1bcc 20. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:0: DB::MergeTreeSelectProcessor::read() @ 0x000000002c8241d2 21. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000002de6d77a 22. ./build_docker/./src/Processors/ISource.cpp:0: DB::ISource::work() @ 0x000000002d3290a1 23. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:381: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000002d34bd35 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7eaf0 27. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001af8a79f 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 30. asan_thread_start(void*) @ 0x000000000aa43059 31. ? @ 0x00007f35aab92ac3 2025.09.09 14:52:58.216376 [ 2825 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:52:58.296549 [ 2828 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:52:58.992610 [ 3604 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 14:52:59.218719 [ 2844 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:52:59.298949 [ 2848 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:52:59.950216 [ 3722 ] {7718236c-d9c3-448e-8a21-2c435e38a12d} executeQuery: Code: 264. DB::Exception: Table test.join (baf0d231-d11f-4946-b8b5-b3b1c548358d) needs the same join_use_nulls setting as present in LEFT or FULL JOIN. (INCOMPATIBLE_TYPE_OF_JOIN) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:35286) (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000aad4b34 4. ./build_docker/./src/Storages/StorageJoin.cpp:239: DB::StorageJoin::getJoinLocked(std::shared_ptr, std::shared_ptr, std::vector> const&) const @ 0x000000002b82f5e2 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&) @ 0x00000000294a520e 6. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1490: DB::(anonymous namespace)::buildQueryPlanForJoinNode(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000002947642f 7. ./build_docker/./src/Planner/PlannerJoinTree.cpp:0: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000002945f174 8. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x000000002942c986 9. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x00000000294261fb 10. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000029421552 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1182: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3737e 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 14. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 19. asan_thread_start(void*) @ 0x000000000aa43059 20. ? @ 0x00007f35aab92ac3 21. ? @ 0x00007f35aac24850 2025.09.09 14:52:59.958668 [ 3722 ] {7718236c-d9c3-448e-8a21-2c435e38a12d} TCPHandler: Code: 264. DB::Exception: Table test.join (baf0d231-d11f-4946-b8b5-b3b1c548358d) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000aad4b34 4. ./build_docker/./src/Storages/StorageJoin.cpp:239: DB::StorageJoin::getJoinLocked(std::shared_ptr, std::shared_ptr, std::vector> const&) const @ 0x000000002b82f5e2 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&) @ 0x00000000294a520e 6. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1490: DB::(anonymous namespace)::buildQueryPlanForJoinNode(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000002947642f 7. ./build_docker/./src/Planner/PlannerJoinTree.cpp:0: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000002945f174 8. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x000000002942c986 9. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x00000000294261fb 10. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000029421552 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1182: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3737e 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 14. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 19. asan_thread_start(void*) @ 0x000000000aa43059 20. ? @ 0x00007f35aab92ac3 21. ? @ 0x00007f35aac24850 2025.09.09 14:53:00.021836 [ 4022 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 14:53:00.222816 [ 2869 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:53:00.301609 [ 2868 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:53:01.069624 [ 3722 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 14:53:01.225127 [ 2881 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:53:01.303817 [ 2888 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:53:02.118366 [ 5359 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 14:53:02.227387 [ 2902 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:53:02.305758 [ 2904 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:53:03.024245 [ 5359 ] {dce0ddbc-1f70-49cd-9e9a-5f330946ef02} executeQuery: Code: 57. DB::Exception: Table test_9.parsing_with_names already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:35434) (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa91e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1558: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291bc5ff 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291ac835 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000291c3415 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b382fc 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 15. asan_thread_start(void*) @ 0x000000000aa43059 16. ? @ 0x00007f35aab92ac3 17. ? @ 0x00007f35aac24850 2025.09.09 14:53:03.056456 [ 5359 ] {dce0ddbc-1f70-49cd-9e9a-5f330946ef02} TCPHandler: Code: 57. DB::Exception: Table test_9.parsing_with_names already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa91e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1558: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291bc5ff 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291ac835 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000291c3415 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b382fc 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 15. asan_thread_start(void*) @ 0x000000000aa43059 16. ? @ 0x00007f35aab92ac3 17. ? @ 0x00007f35aac24850 2025.09.09 14:53:03.147407 [ 4017 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 14:53:03.229471 [ 2918 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:53:03.307775 [ 2926 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:53:04.194546 [ 5359 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 14:53:04.317297 [ 2943 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:53:04.318501 [ 2945 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:53:05.290414 [ 3766 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 14:53:05.319704 [ 2963 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:53:05.325491 [ 2964 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:53:06.319991 [ 5359 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 14:53:06.321821 [ 2994 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:53:06.327700 [ 2990 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:53:07.323845 [ 3008 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:53:07.329960 [ 3011 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:53:07.342054 [ 5359 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 14:53:07.614947 [ 3722 ] {509871a6-8464-4757-afe3-d495d3ec0b4d} 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.10505.altinitytest (altinity build)) (from [::1]:35522) (comment: 01010_partial_merge_join_negative.sql) (in query: SELECT * FROM t0 ANY RIGHT JOIN t1 ON t1.x = t0.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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aac868e 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&) @ 0x00000000294a6d9f 5. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1490: DB::(anonymous namespace)::buildQueryPlanForJoinNode(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000002947642f 6. ./build_docker/./src/Planner/PlannerJoinTree.cpp:0: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000002945f174 7. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x000000002942c986 8. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x00000000294261fb 9. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000029421552 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1182: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3737e 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 13. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 18. asan_thread_start(void*) @ 0x000000000aa43059 19. ? @ 0x00007f35aab92ac3 20. ? @ 0x00007f35aac24850 2025.09.09 14:53:07.617022 [ 3722 ] {509871a6-8464-4757-afe3-d495d3ec0b4d} 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aac868e 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&) @ 0x00000000294a6d9f 5. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1490: DB::(anonymous namespace)::buildQueryPlanForJoinNode(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000002947642f 6. ./build_docker/./src/Planner/PlannerJoinTree.cpp:0: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000002945f174 7. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x000000002942c986 8. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x00000000294261fb 9. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000029421552 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1182: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3737e 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 13. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 18. asan_thread_start(void*) @ 0x000000000aa43059 19. ? @ 0x00007f35aab92ac3 20. ? @ 0x00007f35aac24850 2025.09.09 14:53:07.710115 [ 3722 ] {b886987b-e24f-42cb-a5eb-272092a8bef8} executeQuery: Code: 48. DB::Exception: ANY FULL JOINs are not implemented. (NOT_IMPLEMENTED) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:35522) (comment: 01010_partial_merge_join_negative.sql) (in query: SELECT * FROM t0 ANY FULL JOIN t1 ON t1.x = t0.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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aac868e 4. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:941: DB::(anonymous namespace)::QueryTreeBuilder::buildSelectExpression(std::shared_ptr const&, bool, String const&, std::shared_ptr const&) const @ 0x000000002830a346 5. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryTreeBuilder::buildSelectOrUnionExpression(std::shared_ptr const&, bool, String const&, std::shared_ptr const&) const @ 0x00000000282faf8e 6. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:0: DB::(anonymous namespace)::QueryTreeBuilder::buildSelectWithUnionExpression(std::shared_ptr const&, bool, String const&, std::shared_ptr const&) const @ 0x000000002830033e 7. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryTreeBuilder::buildSelectOrUnionExpression(std::shared_ptr const&, bool, String const&, std::shared_ptr const&) const @ 0x00000000282fae02 8. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::buildQueryTree(std::shared_ptr, std::shared_ptr) @ 0x00000000282fa4e6 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:131: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002941e50e 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&) @ 0x0000000029419aef 11. ./contrib/llvm-project/libcxx/include/vector:432: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000029421f5d 12. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000029344c1b 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*) @ 0x0000000029b3703b 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 16. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 20. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 21. asan_thread_start(void*) @ 0x000000000aa43059 22. ? @ 0x00007f35aab92ac3 23. ? @ 0x00007f35aac24850 2025.09.09 14:53:07.714338 [ 3722 ] {b886987b-e24f-42cb-a5eb-272092a8bef8} TCPHandler: Code: 48. DB::Exception: ANY FULL JOINs are not implemented. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aac868e 4. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:941: DB::(anonymous namespace)::QueryTreeBuilder::buildSelectExpression(std::shared_ptr const&, bool, String const&, std::shared_ptr const&) const @ 0x000000002830a346 5. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryTreeBuilder::buildSelectOrUnionExpression(std::shared_ptr const&, bool, String const&, std::shared_ptr const&) const @ 0x00000000282faf8e 6. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:0: DB::(anonymous namespace)::QueryTreeBuilder::buildSelectWithUnionExpression(std::shared_ptr const&, bool, String const&, std::shared_ptr const&) const @ 0x000000002830033e 7. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryTreeBuilder::buildSelectOrUnionExpression(std::shared_ptr const&, bool, String const&, std::shared_ptr const&) const @ 0x00000000282fae02 8. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::buildQueryTree(std::shared_ptr, std::shared_ptr) @ 0x00000000282fa4e6 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:131: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002941e50e 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&) @ 0x0000000029419aef 11. ./contrib/llvm-project/libcxx/include/vector:432: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000029421f5d 12. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000029344c1b 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*) @ 0x0000000029b3703b 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 16. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 20. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 21. asan_thread_start(void*) @ 0x000000000aa43059 22. ? @ 0x00007f35aab92ac3 23. ? @ 0x00007f35aac24850 2025.09.09 14:53:08.005181 [ 3722 ] {7ef36151-cc9c-4c8d-87ec-e54654aa3773} 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.10505.altinitytest (altinity build)) (from [::1]:35522) (comment: 01010_partial_merge_join_negative.sql) (in query: SELECT * FROM t0 ANY RIGHT JOIN t1 USING (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aac868e 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&) @ 0x00000000294a6d9f 5. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1490: DB::(anonymous namespace)::buildQueryPlanForJoinNode(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000002947642f 6. ./build_docker/./src/Planner/PlannerJoinTree.cpp:0: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000002945f174 7. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x000000002942c986 8. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x00000000294261fb 9. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000029421552 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1182: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3737e 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 13. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 18. asan_thread_start(void*) @ 0x000000000aa43059 19. ? @ 0x00007f35aab92ac3 20. ? @ 0x00007f35aac24850 2025.09.09 14:53:08.008587 [ 3722 ] {7ef36151-cc9c-4c8d-87ec-e54654aa3773} 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aac868e 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&) @ 0x00000000294a6d9f 5. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1490: DB::(anonymous namespace)::buildQueryPlanForJoinNode(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000002947642f 6. ./build_docker/./src/Planner/PlannerJoinTree.cpp:0: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000002945f174 7. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x000000002942c986 8. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x00000000294261fb 9. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000029421552 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1182: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3737e 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 13. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 18. asan_thread_start(void*) @ 0x000000000aa43059 19. ? @ 0x00007f35aab92ac3 20. ? @ 0x00007f35aac24850 2025.09.09 14:53:08.058411 [ 3722 ] {3c847121-c07a-4a66-ac07-a5e95b06420f} executeQuery: Code: 48. DB::Exception: ANY FULL JOINs are not implemented. (NOT_IMPLEMENTED) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:35522) (comment: 01010_partial_merge_join_negative.sql) (in query: SELECT * FROM t0 ANY FULL JOIN t1 USING (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aac868e 4. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:941: DB::(anonymous namespace)::QueryTreeBuilder::buildSelectExpression(std::shared_ptr const&, bool, String const&, std::shared_ptr const&) const @ 0x000000002830a346 5. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryTreeBuilder::buildSelectOrUnionExpression(std::shared_ptr const&, bool, String const&, std::shared_ptr const&) const @ 0x00000000282faf8e 6. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:0: DB::(anonymous namespace)::QueryTreeBuilder::buildSelectWithUnionExpression(std::shared_ptr const&, bool, String const&, std::shared_ptr const&) const @ 0x000000002830033e 7. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryTreeBuilder::buildSelectOrUnionExpression(std::shared_ptr const&, bool, String const&, std::shared_ptr const&) const @ 0x00000000282fae02 8. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::buildQueryTree(std::shared_ptr, std::shared_ptr) @ 0x00000000282fa4e6 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:131: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002941e50e 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&) @ 0x0000000029419aef 11. ./contrib/llvm-project/libcxx/include/vector:432: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000029421f5d 12. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000029344c1b 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*) @ 0x0000000029b3703b 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 16. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 20. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 21. asan_thread_start(void*) @ 0x000000000aa43059 22. ? @ 0x00007f35aab92ac3 23. ? @ 0x00007f35aac24850 2025.09.09 14:53:08.064595 [ 3722 ] {3c847121-c07a-4a66-ac07-a5e95b06420f} TCPHandler: Code: 48. DB::Exception: ANY FULL JOINs are not implemented. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aac868e 4. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:941: DB::(anonymous namespace)::QueryTreeBuilder::buildSelectExpression(std::shared_ptr const&, bool, String const&, std::shared_ptr const&) const @ 0x000000002830a346 5. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryTreeBuilder::buildSelectOrUnionExpression(std::shared_ptr const&, bool, String const&, std::shared_ptr const&) const @ 0x00000000282faf8e 6. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:0: DB::(anonymous namespace)::QueryTreeBuilder::buildSelectWithUnionExpression(std::shared_ptr const&, bool, String const&, std::shared_ptr const&) const @ 0x000000002830033e 7. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryTreeBuilder::buildSelectOrUnionExpression(std::shared_ptr const&, bool, String const&, std::shared_ptr const&) const @ 0x00000000282fae02 8. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::buildQueryTree(std::shared_ptr, std::shared_ptr) @ 0x00000000282fa4e6 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:131: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002941e50e 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&) @ 0x0000000029419aef 11. ./contrib/llvm-project/libcxx/include/vector:432: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000029421f5d 12. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000029344c1b 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*) @ 0x0000000029b3703b 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 16. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 20. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 21. asan_thread_start(void*) @ 0x000000000aa43059 22. ? @ 0x00007f35aab92ac3 23. ? @ 0x00007f35aac24850 2025.09.09 14:53:08.325640 [ 3026 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:53:08.331968 [ 3022 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:53:08.345113 [ 3722 ] {c2ef68d6-0032-4688-bb74-de7cb64c9233} 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.10505.altinitytest (altinity build)) (from [::1]:35522) (comment: 01010_partial_merge_join_negative.sql) (in query: SELECT * FROM t0 SEMI RIGHT JOIN t1 ON t1.x = t0.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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aac868e 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&) @ 0x00000000294a6d9f 5. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1490: DB::(anonymous namespace)::buildQueryPlanForJoinNode(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000002947642f 6. ./build_docker/./src/Planner/PlannerJoinTree.cpp:0: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000002945f174 7. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x000000002942c986 8. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x00000000294261fb 9. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000029421552 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1182: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3737e 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 13. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 18. asan_thread_start(void*) @ 0x000000000aa43059 19. ? @ 0x00007f35aab92ac3 20. ? @ 0x00007f35aac24850 2025.09.09 14:53:08.352068 [ 3722 ] {c2ef68d6-0032-4688-bb74-de7cb64c9233} 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aac868e 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&) @ 0x00000000294a6d9f 5. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1490: DB::(anonymous namespace)::buildQueryPlanForJoinNode(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000002947642f 6. ./build_docker/./src/Planner/PlannerJoinTree.cpp:0: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000002945f174 7. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x000000002942c986 8. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x00000000294261fb 9. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000029421552 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1182: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3737e 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 13. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 18. asan_thread_start(void*) @ 0x000000000aa43059 19. ? @ 0x00007f35aab92ac3 20. ? @ 0x00007f35aac24850 2025.09.09 14:53:08.358908 [ 2686 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 14:53:08.611836 [ 3722 ] {a05a4c66-87b8-4c4e-9d5d-72899b860779} 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.10505.altinitytest (altinity build)) (from [::1]:35522) (comment: 01010_partial_merge_join_negative.sql) (in query: SELECT * FROM t0 SEMI RIGHT JOIN t1 USING (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aac868e 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&) @ 0x00000000294a6d9f 5. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1490: DB::(anonymous namespace)::buildQueryPlanForJoinNode(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000002947642f 6. ./build_docker/./src/Planner/PlannerJoinTree.cpp:0: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000002945f174 7. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x000000002942c986 8. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x00000000294261fb 9. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000029421552 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1182: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3737e 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 13. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 18. asan_thread_start(void*) @ 0x000000000aa43059 19. ? @ 0x00007f35aab92ac3 20. ? @ 0x00007f35aac24850 2025.09.09 14:53:08.614008 [ 3722 ] {a05a4c66-87b8-4c4e-9d5d-72899b860779} 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aac868e 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&) @ 0x00000000294a6d9f 5. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1490: DB::(anonymous namespace)::buildQueryPlanForJoinNode(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000002947642f 6. ./build_docker/./src/Planner/PlannerJoinTree.cpp:0: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000002945f174 7. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x000000002942c986 8. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x00000000294261fb 9. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000029421552 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1182: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3737e 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 13. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 18. asan_thread_start(void*) @ 0x000000000aa43059 19. ? @ 0x00007f35aab92ac3 20. ? @ 0x00007f35aac24850 2025.09.09 14:53:09.164389 [ 3722 ] {3e31628e-0d63-4702-97bf-00efe5b76842} 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.10505.altinitytest (altinity build)) (from [::1]:35522) (comment: 01010_partial_merge_join_negative.sql) (in query: SELECT * FROM t0 ANTI LEFT JOIN t1 ON t1.x = t0.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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aac868e 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&) @ 0x00000000294a6d9f 5. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1490: DB::(anonymous namespace)::buildQueryPlanForJoinNode(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000002947642f 6. ./build_docker/./src/Planner/PlannerJoinTree.cpp:0: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000002945f174 7. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x000000002942c986 8. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x00000000294261fb 9. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000029421552 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1182: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3737e 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 13. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 18. asan_thread_start(void*) @ 0x000000000aa43059 19. ? @ 0x00007f35aab92ac3 20. ? @ 0x00007f35aac24850 2025.09.09 14:53:09.175029 [ 3722 ] {3e31628e-0d63-4702-97bf-00efe5b76842} 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aac868e 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&) @ 0x00000000294a6d9f 5. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1490: DB::(anonymous namespace)::buildQueryPlanForJoinNode(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000002947642f 6. ./build_docker/./src/Planner/PlannerJoinTree.cpp:0: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000002945f174 7. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x000000002942c986 8. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x00000000294261fb 9. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000029421552 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1182: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3737e 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 13. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 18. asan_thread_start(void*) @ 0x000000000aa43059 19. ? @ 0x00007f35aab92ac3 20. ? @ 0x00007f35aac24850 2025.09.09 14:53:09.268783 [ 3722 ] {78786fe6-7e73-4106-ba6f-6d2bd0caa41e} 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.10505.altinitytest (altinity build)) (from [::1]:35522) (comment: 01010_partial_merge_join_negative.sql) (in query: SELECT * FROM t0 ANTI RIGHT JOIN t1 ON t1.x = t0.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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aac868e 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&) @ 0x00000000294a6d9f 5. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1490: DB::(anonymous namespace)::buildQueryPlanForJoinNode(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000002947642f 6. ./build_docker/./src/Planner/PlannerJoinTree.cpp:0: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000002945f174 7. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x000000002942c986 8. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x00000000294261fb 9. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000029421552 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1182: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3737e 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 13. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 18. asan_thread_start(void*) @ 0x000000000aa43059 19. ? @ 0x00007f35aab92ac3 20. ? @ 0x00007f35aac24850 2025.09.09 14:53:09.275134 [ 3722 ] {78786fe6-7e73-4106-ba6f-6d2bd0caa41e} 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aac868e 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&) @ 0x00000000294a6d9f 5. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1490: DB::(anonymous namespace)::buildQueryPlanForJoinNode(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000002947642f 6. ./build_docker/./src/Planner/PlannerJoinTree.cpp:0: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000002945f174 7. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x000000002942c986 8. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x00000000294261fb 9. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000029421552 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1182: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3737e 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 13. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 18. asan_thread_start(void*) @ 0x000000000aa43059 19. ? @ 0x00007f35aab92ac3 20. ? @ 0x00007f35aac24850 2025.09.09 14:53:09.327496 [ 3042 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:53:09.334052 [ 3043 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:53:09.363581 [ 2686 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 14:53:09.520112 [ 3722 ] {1bcc0ef0-a0fe-402a-9be0-adbca6fd8750} 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.10505.altinitytest (altinity build)) (from [::1]:35522) (comment: 01010_partial_merge_join_negative.sql) (in query: SELECT * FROM t0 ANTI LEFT JOIN t1 USING (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aac868e 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&) @ 0x00000000294a6d9f 5. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1490: DB::(anonymous namespace)::buildQueryPlanForJoinNode(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000002947642f 6. ./build_docker/./src/Planner/PlannerJoinTree.cpp:0: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000002945f174 7. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x000000002942c986 8. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x00000000294261fb 9. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000029421552 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1182: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3737e 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 13. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 18. asan_thread_start(void*) @ 0x000000000aa43059 19. ? @ 0x00007f35aab92ac3 20. ? @ 0x00007f35aac24850 2025.09.09 14:53:09.521746 [ 3722 ] {1bcc0ef0-a0fe-402a-9be0-adbca6fd8750} 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aac868e 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&) @ 0x00000000294a6d9f 5. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1490: DB::(anonymous namespace)::buildQueryPlanForJoinNode(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000002947642f 6. ./build_docker/./src/Planner/PlannerJoinTree.cpp:0: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000002945f174 7. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x000000002942c986 8. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x00000000294261fb 9. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000029421552 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1182: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3737e 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 13. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 18. asan_thread_start(void*) @ 0x000000000aa43059 19. ? @ 0x00007f35aab92ac3 20. ? @ 0x00007f35aac24850 2025.09.09 14:53:09.548086 [ 3722 ] {6e12ef8a-542d-4ba7-867e-42f6a2b331cc} 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.10505.altinitytest (altinity build)) (from [::1]:35522) (comment: 01010_partial_merge_join_negative.sql) (in query: SELECT * FROM t0 ANTI RIGHT JOIN t1 USING (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aac868e 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&) @ 0x00000000294a6d9f 5. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1490: DB::(anonymous namespace)::buildQueryPlanForJoinNode(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000002947642f 6. ./build_docker/./src/Planner/PlannerJoinTree.cpp:0: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000002945f174 7. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x000000002942c986 8. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x00000000294261fb 9. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000029421552 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1182: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3737e 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 13. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 18. asan_thread_start(void*) @ 0x000000000aa43059 19. ? @ 0x00007f35aab92ac3 20. ? @ 0x00007f35aac24850 2025.09.09 14:53:09.550563 [ 3722 ] {6e12ef8a-542d-4ba7-867e-42f6a2b331cc} 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aac868e 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&) @ 0x00000000294a6d9f 5. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1490: DB::(anonymous namespace)::buildQueryPlanForJoinNode(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000002947642f 6. ./build_docker/./src/Planner/PlannerJoinTree.cpp:0: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000002945f174 7. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x000000002942c986 8. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x00000000294261fb 9. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000029421552 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1182: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3737e 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 13. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 18. asan_thread_start(void*) @ 0x000000000aa43059 19. ? @ 0x00007f35aab92ac3 20. ? @ 0x00007f35aac24850 2025.09.09 14:53:09.743538 [ 3722 ] {459b37fe-ccd7-44f2-8ce0-d81f47b9469e} 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.10505.altinitytest (altinity build)) (from [::1]:35522) (comment: 01010_partial_merge_join_negative.sql) (in query: SELECT * FROM t0 ASOF LEFT JOIN t1 ON t1.x = t0.x AND t0.y > t1.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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aac868e 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&) @ 0x00000000294a6d9f 5. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1490: DB::(anonymous namespace)::buildQueryPlanForJoinNode(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000002947642f 6. ./build_docker/./src/Planner/PlannerJoinTree.cpp:0: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000002945f174 7. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x000000002942c986 8. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x00000000294261fb 9. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000029421552 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1182: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3737e 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 13. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 18. asan_thread_start(void*) @ 0x000000000aa43059 19. ? @ 0x00007f35aab92ac3 20. ? @ 0x00007f35aac24850 2025.09.09 14:53:09.745395 [ 3722 ] {459b37fe-ccd7-44f2-8ce0-d81f47b9469e} 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aac868e 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&) @ 0x00000000294a6d9f 5. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1490: DB::(anonymous namespace)::buildQueryPlanForJoinNode(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000002947642f 6. ./build_docker/./src/Planner/PlannerJoinTree.cpp:0: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000002945f174 7. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x000000002942c986 8. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x00000000294261fb 9. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000029421552 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1182: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3737e 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 13. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 18. asan_thread_start(void*) @ 0x000000000aa43059 19. ? @ 0x00007f35aab92ac3 20. ? @ 0x00007f35aac24850 2025.09.09 14:53:09.782604 [ 3722 ] {7fbc05ca-3b9a-4170-a6f2-ce9b44b52e1b} 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.10505.altinitytest (altinity build)) (from [::1]:35522) (comment: 01010_partial_merge_join_negative.sql) (in query: SELECT * FROM t0 ASOF LEFT JOIN t1 USING (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aac868e 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&) @ 0x00000000294a6d9f 5. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1490: DB::(anonymous namespace)::buildQueryPlanForJoinNode(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000002947642f 6. ./build_docker/./src/Planner/PlannerJoinTree.cpp:0: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000002945f174 7. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x000000002942c986 8. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x00000000294261fb 9. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000029421552 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1182: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3737e 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 13. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 18. asan_thread_start(void*) @ 0x000000000aa43059 19. ? @ 0x00007f35aab92ac3 20. ? @ 0x00007f35aac24850 2025.09.09 14:53:09.785180 [ 3722 ] {7fbc05ca-3b9a-4170-a6f2-ce9b44b52e1b} 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aac868e 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&) @ 0x00000000294a6d9f 5. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1490: DB::(anonymous namespace)::buildQueryPlanForJoinNode(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000002947642f 6. ./build_docker/./src/Planner/PlannerJoinTree.cpp:0: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000002945f174 7. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x000000002942c986 8. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x00000000294261fb 9. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000029421552 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1182: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3737e 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 13. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 18. asan_thread_start(void*) @ 0x000000000aa43059 19. ? @ 0x00007f35aab92ac3 20. ? @ 0x00007f35aac24850 2025.09.09 14:53:10.329659 [ 3063 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:53:10.337128 [ 3066 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:53:10.414392 [ 4025 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 14:53:10.979757 [ 5439 ] {cbfa5096-7bc0-4937-92bf-1f03301a9d1c} void DB::ParallelParsingInputFormat::onBackgroundException(): Code: 117. DB::Exception: Duplicate field found while parsing BSONEachRow format: x: (at row 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type>, StringRef&) @ 0x000000002d4a1574 4. ./build_docker/./src/Processors/Formats/Impl/BSONEachRowRowInputFormat.cpp:809: DB::BSONEachRowRowInputFormat::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x000000002d499a1f 5. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:0: DB::IRowInputFormat::read() @ 0x000000002d46d965 6. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000002d37a746 7. ./src/Processors/Chunk.h:110: DB::ISource::tryGenerate() @ 0x000000002d329c18 8. ./build_docker/./src/Processors/ISource.cpp:0: DB::ISource::work() @ 0x000000002d3290a1 9. ./src/Processors/Formats/Impl/ParallelParsingInputFormat.h:0: DB::ParallelParsingInputFormat::InternalParser::getChunk() @ 0x000000002d6fa5e9 10. ./contrib/llvm-project/libcxx/include/vector:961: DB::ParallelParsingInputFormat::parserThreadFunction(std::shared_ptr, unsigned long) @ 0x000000002d6f7281 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7eaf0 12. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001af8a79f 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 15. asan_thread_start(void*) @ 0x000000000aa43059 16. ? @ 0x00007f35aab92ac3 17. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:53:10.989144 [ 3722 ] {cbfa5096-7bc0-4937-92bf-1f03301a9d1c} executeQuery: Code: 117. DB::Exception: Duplicate field found while parsing BSONEachRow format: x: (at row 1) : While executing ParallelParsingBlockInputFormat. (INCORRECT_DATA) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:60734) (comment: 02590_bson_duplicate_column.sql) (in query: select * from format(BSONEachRow, 'x UInt32, y UInt32', x'1a0000001078002a0000001078002a0000001079002a00000000');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type>, StringRef&) @ 0x000000002d4a1574 4. ./build_docker/./src/Processors/Formats/Impl/BSONEachRowRowInputFormat.cpp:809: DB::BSONEachRowRowInputFormat::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x000000002d499a1f 5. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:0: DB::IRowInputFormat::read() @ 0x000000002d46d965 6. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000002d37a746 7. ./src/Processors/Chunk.h:110: DB::ISource::tryGenerate() @ 0x000000002d329c18 8. ./build_docker/./src/Processors/ISource.cpp:0: DB::ISource::work() @ 0x000000002d3290a1 9. ./src/Processors/Formats/Impl/ParallelParsingInputFormat.h:0: DB::ParallelParsingInputFormat::InternalParser::getChunk() @ 0x000000002d6fa5e9 10. ./contrib/llvm-project/libcxx/include/vector:961: DB::ParallelParsingInputFormat::parserThreadFunction(std::shared_ptr, unsigned long) @ 0x000000002d6f7281 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7eaf0 12. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001af8a79f 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 15. asan_thread_start(void*) @ 0x000000000aa43059 16. ? @ 0x00007f35aab92ac3 17. ? @ 0x00007f35aac24850 2025.09.09 14:53:10.990925 [ 3722 ] {cbfa5096-7bc0-4937-92bf-1f03301a9d1c} TCPHandler: Code: 117. DB::Exception: Duplicate field found while parsing BSONEachRow format: x: (at row 1) : While executing ParallelParsingBlockInputFormat. (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type>, StringRef&) @ 0x000000002d4a1574 4. ./build_docker/./src/Processors/Formats/Impl/BSONEachRowRowInputFormat.cpp:809: DB::BSONEachRowRowInputFormat::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x000000002d499a1f 5. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:0: DB::IRowInputFormat::read() @ 0x000000002d46d965 6. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000002d37a746 7. ./src/Processors/Chunk.h:110: DB::ISource::tryGenerate() @ 0x000000002d329c18 8. ./build_docker/./src/Processors/ISource.cpp:0: DB::ISource::work() @ 0x000000002d3290a1 9. ./src/Processors/Formats/Impl/ParallelParsingInputFormat.h:0: DB::ParallelParsingInputFormat::InternalParser::getChunk() @ 0x000000002d6fa5e9 10. ./contrib/llvm-project/libcxx/include/vector:961: DB::ParallelParsingInputFormat::parserThreadFunction(std::shared_ptr, unsigned long) @ 0x000000002d6f7281 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7eaf0 12. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001af8a79f 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 15. asan_thread_start(void*) @ 0x000000000aa43059 16. ? @ 0x00007f35aab92ac3 17. ? @ 0x00007f35aac24850 2025.09.09 14:53:11.331744 [ 3087 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:53:11.343021 [ 3088 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:53:11.482386 [ 2688 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 14:53:11.840875 [ 2688 ] {d9f0158a-aa5b-4d7e-afd5-4d873d3653a3} executeQuery: Code: 43. DB::Exception: Function toStartOfDay supports a 2nd argument (optional) that must be a valid time zone: In scope SELECT toStartOfDay(toDateTime('2017-12-31 00:00:00', 'UTC'), ''). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:60760) (comment: 01472_toBoundsOfInterval_disallow_empty_tz_field.sql) (in query: SELECT toStartOfDay(toDateTime('2017-12-31 00:00:00', 'UTC'), '');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000aad4b34 4. DB::FunctionDateOrDateTimeToDateTimeOrDateTime64::getReturnTypeImpl(std::vector> const&) const @ 0x000000001869f429 5. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000ccd376e 6. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000ccd3176 7. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000ccd4343 8. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000028399ff0 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000028367bce 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028366290 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283b62c9 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002835ae03 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000028359104 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000028357f0d 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002921bdcc 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&) @ 0x000000002941f313 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&) @ 0x0000000029419aef 18. ./contrib/llvm-project/libcxx/include/vector:432: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000029421f5d 19. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000029344c1b 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*) @ 0x0000000029b3703b 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 27. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 28. asan_thread_start(void*) @ 0x000000000aa43059 29. ? @ 0x00007f35aab92ac3 30. ? @ 0x00007f35aac24850 2025.09.09 14:53:11.846847 [ 2688 ] {d9f0158a-aa5b-4d7e-afd5-4d873d3653a3} TCPHandler: Code: 43. DB::Exception: Function toStartOfDay supports a 2nd argument (optional) that must be a valid time zone: In scope SELECT toStartOfDay(toDateTime('2017-12-31 00:00:00', 'UTC'), ''). (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000aad4b34 4. DB::FunctionDateOrDateTimeToDateTimeOrDateTime64::getReturnTypeImpl(std::vector> const&) const @ 0x000000001869f429 5. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000ccd376e 6. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000ccd3176 7. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000ccd4343 8. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000028399ff0 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000028367bce 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028366290 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283b62c9 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002835ae03 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000028359104 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000028357f0d 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002921bdcc 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&) @ 0x000000002941f313 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&) @ 0x0000000029419aef 18. ./contrib/llvm-project/libcxx/include/vector:432: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000029421f5d 19. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000029344c1b 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*) @ 0x0000000029b3703b 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 27. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 28. asan_thread_start(void*) @ 0x000000000aa43059 29. ? @ 0x00007f35aab92ac3 30. ? @ 0x00007f35aac24850 2025.09.09 14:53:12.294105 [ 2688 ] {e2499125-6002-4293-aad3-3784dfe0a73c} executeQuery: Code: 43. DB::Exception: Function toMonday supports a 2nd argument (optional) that must be a valid time zone: In scope SELECT toMonday(toDateTime('2017-12-31 00:00:00', 'UTC'), ''). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:60760) (comment: 01472_toBoundsOfInterval_disallow_empty_tz_field.sql) (in query: SELECT toMonday(toDateTime('2017-12-31 00:00:00', 'UTC'), '');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000aad4b34 4. DB::FunctionDateOrDateTimeToDateOrDate32::getReturnTypeImpl(std::vector> const&) const @ 0x000000001865596a 5. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000ccd376e 6. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000ccd3176 7. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000ccd4343 8. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000028399ff0 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000028367bce 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028366290 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283b62c9 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002835ae03 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000028359104 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000028357f0d 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002921bdcc 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&) @ 0x000000002941f313 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&) @ 0x0000000029419aef 18. ./contrib/llvm-project/libcxx/include/vector:432: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000029421f5d 19. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000029344c1b 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*) @ 0x0000000029b3703b 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 27. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 28. asan_thread_start(void*) @ 0x000000000aa43059 29. ? @ 0x00007f35aab92ac3 30. ? @ 0x00007f35aac24850 2025.09.09 14:53:12.299147 [ 2688 ] {e2499125-6002-4293-aad3-3784dfe0a73c} TCPHandler: Code: 43. DB::Exception: Function toMonday supports a 2nd argument (optional) that must be a valid time zone: In scope SELECT toMonday(toDateTime('2017-12-31 00:00:00', 'UTC'), ''). (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000aad4b34 4. DB::FunctionDateOrDateTimeToDateOrDate32::getReturnTypeImpl(std::vector> const&) const @ 0x000000001865596a 5. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000ccd376e 6. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000ccd3176 7. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000ccd4343 8. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000028399ff0 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000028367bce 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028366290 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283b62c9 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002835ae03 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000028359104 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000028357f0d 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002921bdcc 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&) @ 0x000000002941f313 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&) @ 0x0000000029419aef 18. ./contrib/llvm-project/libcxx/include/vector:432: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000029421f5d 19. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000029344c1b 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*) @ 0x0000000029b3703b 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 27. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 28. asan_thread_start(void*) @ 0x000000000aa43059 29. ? @ 0x00007f35aab92ac3 30. ? @ 0x00007f35aac24850 2025.09.09 14:53:12.333720 [ 3104 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:53:12.351901 [ 3105 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:53:12.494960 [ 4025 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 14:53:12.788017 [ 2688 ] {34b58013-4027-49c3-959d-1568aa9f7cd9} executeQuery: Code: 43. DB::Exception: Provided time zone must be non-empty and be a valid time zone: In scope SELECT toStartOfWeek(toDateTime('2017-12-31 00:00:00', 'UTC'), 0, ''). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:60760) (comment: 01472_toBoundsOfInterval_disallow_empty_tz_field.sql) (in query: SELECT toStartOfWeek(toDateTime('2017-12-31 00:00:00', 'UTC'), 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aac868e 4. DB::extractTimeZoneFromFunctionArguments(std::vector> const&, unsigned long, unsigned long) @ 0x000000000fcc9899 5. COW::immutable_ptr DB::CustomWeekTransformImpl::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::ToStartOfWeekImpl) @ 0x00000000185dac25 6. DB::FunctionCustomWeekToDateOrDate32::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000185d6ca5 7. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aa8c635 8. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aac91d5 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000cccccfb 10. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000cccc1ab 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccccc2a 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccce65c 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd2030 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002839a3af 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000028367bce 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028366290 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283b62c9 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002835ae03 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000028359104 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000028357f0d 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002921bdcc 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&) @ 0x000000002941f313 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&) @ 0x0000000029419aef 24. ./contrib/llvm-project/libcxx/include/vector:432: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000029421f5d 25. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000029344c1b 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*) @ 0x0000000029b3703b 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 28. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 29. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 2025.09.09 14:53:12.792709 [ 2688 ] {34b58013-4027-49c3-959d-1568aa9f7cd9} TCPHandler: Code: 43. DB::Exception: Provided time zone must be non-empty and be a valid time zone: In scope SELECT toStartOfWeek(toDateTime('2017-12-31 00:00:00', 'UTC'), 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aac868e 4. DB::extractTimeZoneFromFunctionArguments(std::vector> const&, unsigned long, unsigned long) @ 0x000000000fcc9899 5. COW::immutable_ptr DB::CustomWeekTransformImpl::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::ToStartOfWeekImpl) @ 0x00000000185dac25 6. DB::FunctionCustomWeekToDateOrDate32::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000185d6ca5 7. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aa8c635 8. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aac91d5 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000cccccfb 10. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000cccc1ab 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccccc2a 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccce65c 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd2030 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002839a3af 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000028367bce 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028366290 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283b62c9 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002835ae03 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000028359104 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000028357f0d 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002921bdcc 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&) @ 0x000000002941f313 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&) @ 0x0000000029419aef 24. ./contrib/llvm-project/libcxx/include/vector:432: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000029421f5d 25. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000029344c1b 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*) @ 0x0000000029b3703b 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 28. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 29. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 2025.09.09 14:53:12.992296 [ 2688 ] {6b621a61-d2ac-4547-8b38-61dbd8778479} executeQuery: Code: 43. DB::Exception: Provided time zone must be non-empty and be a valid time zone: In scope SELECT toStartOfWeek(toDateTime('2017-12-31 00:00:00', 'UTC'), 1, ''). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:60760) (comment: 01472_toBoundsOfInterval_disallow_empty_tz_field.sql) (in query: SELECT toStartOfWeek(toDateTime('2017-12-31 00:00:00', 'UTC'), 1, '');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aac868e 4. DB::extractTimeZoneFromFunctionArguments(std::vector> const&, unsigned long, unsigned long) @ 0x000000000fcc9899 5. COW::immutable_ptr DB::CustomWeekTransformImpl::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::ToStartOfWeekImpl) @ 0x00000000185dac25 6. DB::FunctionCustomWeekToDateOrDate32::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000185d6ca5 7. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aa8c635 8. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aac91d5 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000cccccfb 10. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000cccc1ab 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccccc2a 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccce65c 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd2030 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002839a3af 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000028367bce 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028366290 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283b62c9 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002835ae03 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000028359104 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000028357f0d 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002921bdcc 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&) @ 0x000000002941f313 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&) @ 0x0000000029419aef 24. ./contrib/llvm-project/libcxx/include/vector:432: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000029421f5d 25. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000029344c1b 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*) @ 0x0000000029b3703b 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 28. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 29. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 2025.09.09 14:53:12.999907 [ 2688 ] {6b621a61-d2ac-4547-8b38-61dbd8778479} TCPHandler: Code: 43. DB::Exception: Provided time zone must be non-empty and be a valid time zone: In scope SELECT toStartOfWeek(toDateTime('2017-12-31 00:00:00', 'UTC'), 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aac868e 4. DB::extractTimeZoneFromFunctionArguments(std::vector> const&, unsigned long, unsigned long) @ 0x000000000fcc9899 5. COW::immutable_ptr DB::CustomWeekTransformImpl::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::ToStartOfWeekImpl) @ 0x00000000185dac25 6. DB::FunctionCustomWeekToDateOrDate32::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000185d6ca5 7. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aa8c635 8. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aac91d5 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000cccccfb 10. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000cccc1ab 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccccc2a 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccce65c 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd2030 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002839a3af 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000028367bce 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028366290 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283b62c9 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002835ae03 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000028359104 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000028357f0d 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002921bdcc 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&) @ 0x000000002941f313 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&) @ 0x0000000029419aef 24. ./contrib/llvm-project/libcxx/include/vector:432: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000029421f5d 25. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000029344c1b 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*) @ 0x0000000029b3703b 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 28. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 29. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 2025.09.09 14:53:13.335822 [ 3120 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:53:13.354047 [ 3121 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:53:13.489684 [ 2688 ] {bb0af7f1-163b-40f1-9f92-ef6632a95336} executeQuery: Code: 43. DB::Exception: Provided time zone must be non-empty and be a valid time zone: In scope SELECT toLastDayOfWeek(toDateTime('2017-12-31 00:00:00', 'UTC'), 0, ''). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:60760) (comment: 01472_toBoundsOfInterval_disallow_empty_tz_field.sql) (in query: SELECT toLastDayOfWeek(toDateTime('2017-12-31 00:00:00', 'UTC'), 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aac868e 4. DB::extractTimeZoneFromFunctionArguments(std::vector> const&, unsigned long, unsigned long) @ 0x000000000fcc9899 5. COW::immutable_ptr DB::CustomWeekTransformImpl::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::ToLastDayOfWeekImpl) @ 0x00000000185e38a5 6. DB::FunctionCustomWeekToDateOrDate32::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000185dff05 7. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aa8c635 8. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aac91d5 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000cccccfb 10. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000cccc1ab 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccccc2a 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccce65c 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd2030 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002839a3af 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000028367bce 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028366290 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283b62c9 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002835ae03 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000028359104 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000028357f0d 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002921bdcc 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&) @ 0x000000002941f313 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&) @ 0x0000000029419aef 24. ./contrib/llvm-project/libcxx/include/vector:432: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000029421f5d 25. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000029344c1b 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*) @ 0x0000000029b3703b 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 28. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 29. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 2025.09.09 14:53:13.494106 [ 2688 ] {bb0af7f1-163b-40f1-9f92-ef6632a95336} TCPHandler: Code: 43. DB::Exception: Provided time zone must be non-empty and be a valid time zone: In scope SELECT toLastDayOfWeek(toDateTime('2017-12-31 00:00:00', 'UTC'), 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aac868e 4. DB::extractTimeZoneFromFunctionArguments(std::vector> const&, unsigned long, unsigned long) @ 0x000000000fcc9899 5. COW::immutable_ptr DB::CustomWeekTransformImpl::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::ToLastDayOfWeekImpl) @ 0x00000000185e38a5 6. DB::FunctionCustomWeekToDateOrDate32::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000185dff05 7. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aa8c635 8. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aac91d5 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000cccccfb 10. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000cccc1ab 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccccc2a 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccce65c 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd2030 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002839a3af 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000028367bce 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028366290 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283b62c9 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002835ae03 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000028359104 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000028357f0d 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002921bdcc 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&) @ 0x000000002941f313 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&) @ 0x0000000029419aef 24. ./contrib/llvm-project/libcxx/include/vector:432: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000029421f5d 25. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000029344c1b 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*) @ 0x0000000029b3703b 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 28. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 29. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 2025.09.09 14:53:13.556218 [ 2686 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 14:53:13.744465 [ 2688 ] {fd222a52-fc38-49b6-89e7-fc86c08249ef} executeQuery: Code: 43. DB::Exception: Provided time zone must be non-empty and be a valid time zone: In scope SELECT toLastDayOfWeek(toDateTime('2017-12-31 00:00:00', 'UTC'), 1, ''). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:60760) (comment: 01472_toBoundsOfInterval_disallow_empty_tz_field.sql) (in query: SELECT toLastDayOfWeek(toDateTime('2017-12-31 00:00:00', 'UTC'), 1, '');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aac868e 4. DB::extractTimeZoneFromFunctionArguments(std::vector> const&, unsigned long, unsigned long) @ 0x000000000fcc9899 5. COW::immutable_ptr DB::CustomWeekTransformImpl::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::ToLastDayOfWeekImpl) @ 0x00000000185e38a5 6. DB::FunctionCustomWeekToDateOrDate32::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000185dff05 7. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aa8c635 8. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aac91d5 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000cccccfb 10. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000cccc1ab 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccccc2a 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccce65c 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd2030 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002839a3af 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000028367bce 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028366290 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283b62c9 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002835ae03 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000028359104 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000028357f0d 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002921bdcc 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&) @ 0x000000002941f313 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&) @ 0x0000000029419aef 24. ./contrib/llvm-project/libcxx/include/vector:432: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000029421f5d 25. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000029344c1b 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*) @ 0x0000000029b3703b 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 28. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 29. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 2025.09.09 14:53:13.769508 [ 2688 ] {fd222a52-fc38-49b6-89e7-fc86c08249ef} TCPHandler: Code: 43. DB::Exception: Provided time zone must be non-empty and be a valid time zone: In scope SELECT toLastDayOfWeek(toDateTime('2017-12-31 00:00:00', 'UTC'), 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aac868e 4. DB::extractTimeZoneFromFunctionArguments(std::vector> const&, unsigned long, unsigned long) @ 0x000000000fcc9899 5. COW::immutable_ptr DB::CustomWeekTransformImpl::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::ToLastDayOfWeekImpl) @ 0x00000000185e38a5 6. DB::FunctionCustomWeekToDateOrDate32::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000185dff05 7. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aa8c635 8. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aac91d5 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000cccccfb 10. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000cccc1ab 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccccc2a 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccce65c 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd2030 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002839a3af 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000028367bce 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028366290 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283b62c9 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002835ae03 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000028359104 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000028357f0d 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002921bdcc 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&) @ 0x000000002941f313 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&) @ 0x0000000029419aef 24. ./contrib/llvm-project/libcxx/include/vector:432: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000029421f5d 25. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000029344c1b 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*) @ 0x0000000029b3703b 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 28. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 29. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 2025.09.09 14:53:14.169053 [ 2688 ] {07f22946-b80b-45db-8a87-052d0f437f90} executeQuery: Code: 43. DB::Exception: Function toStartOfMonth supports a 2nd argument (optional) that must be a valid time zone: In scope SELECT toStartOfMonth(toDateTime('2017-12-31 00:00:00', 'UTC'), ''). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:60760) (comment: 01472_toBoundsOfInterval_disallow_empty_tz_field.sql) (in query: SELECT toStartOfMonth(toDateTime('2017-12-31 00:00:00', 'UTC'), '');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000aad4b34 4. DB::FunctionDateOrDateTimeToDateOrDate32::getReturnTypeImpl(std::vector> const&) const @ 0x00000000186df82a 5. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000ccd376e 6. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000ccd3176 7. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000ccd4343 8. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000028399ff0 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000028367bce 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028366290 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283b62c9 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002835ae03 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000028359104 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000028357f0d 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002921bdcc 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&) @ 0x000000002941f313 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&) @ 0x0000000029419aef 18. ./contrib/llvm-project/libcxx/include/vector:432: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000029421f5d 19. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000029344c1b 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*) @ 0x0000000029b3703b 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 27. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 28. asan_thread_start(void*) @ 0x000000000aa43059 29. ? @ 0x00007f35aab92ac3 30. ? @ 0x00007f35aac24850 2025.09.09 14:53:14.173222 [ 2688 ] {07f22946-b80b-45db-8a87-052d0f437f90} TCPHandler: Code: 43. DB::Exception: Function toStartOfMonth supports a 2nd argument (optional) that must be a valid time zone: In scope SELECT toStartOfMonth(toDateTime('2017-12-31 00:00:00', 'UTC'), ''). (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000aad4b34 4. DB::FunctionDateOrDateTimeToDateOrDate32::getReturnTypeImpl(std::vector> const&) const @ 0x00000000186df82a 5. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000ccd376e 6. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000ccd3176 7. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000ccd4343 8. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000028399ff0 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000028367bce 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028366290 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283b62c9 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002835ae03 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000028359104 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000028357f0d 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002921bdcc 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&) @ 0x000000002941f313 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&) @ 0x0000000029419aef 18. ./contrib/llvm-project/libcxx/include/vector:432: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000029421f5d 19. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000029344c1b 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*) @ 0x0000000029b3703b 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 27. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 28. asan_thread_start(void*) @ 0x000000000aa43059 29. ? @ 0x00007f35aab92ac3 30. ? @ 0x00007f35aac24850 2025.09.09 14:53:14.351310 [ 3134 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:53:14.400497 [ 3135 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:53:14.634513 [ 2686 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 14:53:14.659130 [ 2688 ] {feb8721f-f1e2-46e9-b2df-bd407ca8dfae} executeQuery: Code: 43. DB::Exception: Function toStartOfQuarter supports a 2nd argument (optional) that must be a valid time zone: In scope SELECT toStartOfQuarter(toDateTime('2017-12-31 00:00:00', 'UTC'), ''). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:60760) (comment: 01472_toBoundsOfInterval_disallow_empty_tz_field.sql) (in query: SELECT toStartOfQuarter(toDateTime('2017-12-31 00:00:00', 'UTC'), '');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000aad4b34 4. DB::FunctionDateOrDateTimeToDateOrDate32::getReturnTypeImpl(std::vector> const&) const @ 0x00000000186e738a 5. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000ccd376e 6. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000ccd3176 7. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000ccd4343 8. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000028399ff0 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000028367bce 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028366290 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283b62c9 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002835ae03 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000028359104 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000028357f0d 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002921bdcc 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&) @ 0x000000002941f313 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&) @ 0x0000000029419aef 18. ./contrib/llvm-project/libcxx/include/vector:432: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000029421f5d 19. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000029344c1b 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*) @ 0x0000000029b3703b 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 27. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 28. asan_thread_start(void*) @ 0x000000000aa43059 29. ? @ 0x00007f35aab92ac3 30. ? @ 0x00007f35aac24850 2025.09.09 14:53:14.671073 [ 2688 ] {feb8721f-f1e2-46e9-b2df-bd407ca8dfae} TCPHandler: Code: 43. DB::Exception: Function toStartOfQuarter supports a 2nd argument (optional) that must be a valid time zone: In scope SELECT toStartOfQuarter(toDateTime('2017-12-31 00:00:00', 'UTC'), ''). (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000aad4b34 4. DB::FunctionDateOrDateTimeToDateOrDate32::getReturnTypeImpl(std::vector> const&) const @ 0x00000000186e738a 5. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000ccd376e 6. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000ccd3176 7. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000ccd4343 8. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000028399ff0 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000028367bce 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028366290 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283b62c9 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002835ae03 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000028359104 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000028357f0d 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002921bdcc 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&) @ 0x000000002941f313 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&) @ 0x0000000029419aef 18. ./contrib/llvm-project/libcxx/include/vector:432: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000029421f5d 19. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000029344c1b 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*) @ 0x0000000029b3703b 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 27. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 28. asan_thread_start(void*) @ 0x000000000aa43059 29. ? @ 0x00007f35aab92ac3 30. ? @ 0x00007f35aac24850 2025.09.09 14:53:15.174363 [ 2688 ] {bdcba23a-0116-4d54-8be7-b933134dbf20} executeQuery: Code: 43. DB::Exception: Function toStartOfYear supports a 2nd argument (optional) that must be a valid time zone: In scope SELECT toStartOfYear(toDateTime('2017-12-31 00:00:00', 'UTC'), ''). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:60760) (comment: 01472_toBoundsOfInterval_disallow_empty_tz_field.sql) (in query: SELECT toStartOfYear(toDateTime('2017-12-31 00:00:00', 'UTC'), '');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000aad4b34 4. DB::FunctionDateOrDateTimeToDateOrDate32::getReturnTypeImpl(std::vector> const&) const @ 0x000000001870a7ea 5. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000ccd376e 6. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000ccd3176 7. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000ccd4343 8. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000028399ff0 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000028367bce 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028366290 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283b62c9 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002835ae03 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000028359104 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000028357f0d 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002921bdcc 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&) @ 0x000000002941f313 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&) @ 0x0000000029419aef 18. ./contrib/llvm-project/libcxx/include/vector:432: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000029421f5d 19. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000029344c1b 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*) @ 0x0000000029b3703b 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 27. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 28. asan_thread_start(void*) @ 0x000000000aa43059 29. ? @ 0x00007f35aab92ac3 30. ? @ 0x00007f35aac24850 2025.09.09 14:53:15.176728 [ 2688 ] {bdcba23a-0116-4d54-8be7-b933134dbf20} TCPHandler: Code: 43. DB::Exception: Function toStartOfYear supports a 2nd argument (optional) that must be a valid time zone: In scope SELECT toStartOfYear(toDateTime('2017-12-31 00:00:00', 'UTC'), ''). (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000aad4b34 4. DB::FunctionDateOrDateTimeToDateOrDate32::getReturnTypeImpl(std::vector> const&) const @ 0x000000001870a7ea 5. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000ccd376e 6. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000ccd3176 7. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000ccd4343 8. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000028399ff0 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000028367bce 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028366290 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283b62c9 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002835ae03 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000028359104 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000028357f0d 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002921bdcc 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&) @ 0x000000002941f313 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&) @ 0x0000000029419aef 18. ./contrib/llvm-project/libcxx/include/vector:432: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000029421f5d 19. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000029344c1b 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*) @ 0x0000000029b3703b 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 27. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 28. asan_thread_start(void*) @ 0x000000000aa43059 29. ? @ 0x00007f35aab92ac3 30. ? @ 0x00007f35aac24850 2025.09.09 14:53:15.353112 [ 3148 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:53:15.403882 [ 3147 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:53:15.488391 [ 2688 ] {98440438-baed-4276-943f-a8f4cf9894d5} executeQuery: Code: 43. DB::Exception: Function toStartOfTenMinutes supports a 2nd argument (optional) that must be a valid time zone: In scope SELECT toStartOfTenMinutes(toDateTime('2017-12-31 00:00:00', 'UTC'), ''). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:60760) (comment: 01472_toBoundsOfInterval_disallow_empty_tz_field.sql) (in query: SELECT toStartOfTenMinutes(toDateTime('2017-12-31 00:00:00', 'UTC'), '');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000aad4b34 4. DB::FunctionDateOrDateTimeToDateTimeOrDateTime64::getReturnTypeImpl(std::vector> const&) const @ 0x0000000018702f09 5. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000ccd376e 6. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000ccd3176 7. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000ccd4343 8. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000028399ff0 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000028367bce 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028366290 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283b62c9 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002835ae03 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000028359104 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000028357f0d 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002921bdcc 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&) @ 0x000000002941f313 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&) @ 0x0000000029419aef 18. ./contrib/llvm-project/libcxx/include/vector:432: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000029421f5d 19. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000029344c1b 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*) @ 0x0000000029b3703b 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 27. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 28. asan_thread_start(void*) @ 0x000000000aa43059 29. ? @ 0x00007f35aab92ac3 30. ? @ 0x00007f35aac24850 2025.09.09 14:53:15.492139 [ 2688 ] {98440438-baed-4276-943f-a8f4cf9894d5} TCPHandler: Code: 43. DB::Exception: Function toStartOfTenMinutes supports a 2nd argument (optional) that must be a valid time zone: In scope SELECT toStartOfTenMinutes(toDateTime('2017-12-31 00:00:00', 'UTC'), ''). (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000aad4b34 4. DB::FunctionDateOrDateTimeToDateTimeOrDateTime64::getReturnTypeImpl(std::vector> const&) const @ 0x0000000018702f09 5. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000ccd376e 6. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000ccd3176 7. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000ccd4343 8. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000028399ff0 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000028367bce 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028366290 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283b62c9 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002835ae03 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000028359104 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000028357f0d 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002921bdcc 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&) @ 0x000000002941f313 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&) @ 0x0000000029419aef 18. ./contrib/llvm-project/libcxx/include/vector:432: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000029421f5d 19. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000029344c1b 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*) @ 0x0000000029b3703b 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 27. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 28. asan_thread_start(void*) @ 0x000000000aa43059 29. ? @ 0x00007f35aab92ac3 30. ? @ 0x00007f35aac24850 2025.09.09 14:53:15.676359 [ 2686 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 14:53:16.044322 [ 2688 ] {5a7dfff2-d071-49c9-9b27-82bf79705a88} executeQuery: Code: 43. DB::Exception: Function toStartOfFifteenMinutes supports a 2nd argument (optional) that must be a valid time zone: In scope SELECT toStartOfFifteenMinutes(toDateTime('2017-12-31 00:00:00', 'UTC'), ''). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:60760) (comment: 01472_toBoundsOfInterval_disallow_empty_tz_field.sql) (in query: SELECT toStartOfFifteenMinutes(toDateTime('2017-12-31 00:00:00', 'UTC'), '');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000aad4b34 4. DB::FunctionDateOrDateTimeToDateTimeOrDateTime64::getReturnTypeImpl(std::vector> const&) const @ 0x00000000186a6d69 5. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000ccd376e 6. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000ccd3176 7. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000ccd4343 8. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000028399ff0 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000028367bce 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028366290 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283b62c9 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002835ae03 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000028359104 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000028357f0d 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002921bdcc 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&) @ 0x000000002941f313 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&) @ 0x0000000029419aef 18. ./contrib/llvm-project/libcxx/include/vector:432: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000029421f5d 19. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000029344c1b 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*) @ 0x0000000029b3703b 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 27. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 28. asan_thread_start(void*) @ 0x000000000aa43059 29. ? @ 0x00007f35aab92ac3 30. ? @ 0x00007f35aac24850 2025.09.09 14:53:16.046679 [ 2688 ] {5a7dfff2-d071-49c9-9b27-82bf79705a88} TCPHandler: Code: 43. DB::Exception: Function toStartOfFifteenMinutes supports a 2nd argument (optional) that must be a valid time zone: In scope SELECT toStartOfFifteenMinutes(toDateTime('2017-12-31 00:00:00', 'UTC'), ''). (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000aad4b34 4. DB::FunctionDateOrDateTimeToDateTimeOrDateTime64::getReturnTypeImpl(std::vector> const&) const @ 0x00000000186a6d69 5. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000ccd376e 6. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000ccd3176 7. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000ccd4343 8. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000028399ff0 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000028367bce 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028366290 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283b62c9 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002835ae03 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000028359104 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000028357f0d 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002921bdcc 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&) @ 0x000000002941f313 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&) @ 0x0000000029419aef 18. ./contrib/llvm-project/libcxx/include/vector:432: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000029421f5d 19. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000029344c1b 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*) @ 0x0000000029b3703b 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 27. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 28. asan_thread_start(void*) @ 0x000000000aa43059 29. ? @ 0x00007f35aab92ac3 30. ? @ 0x00007f35aac24850 2025.09.09 14:53:16.355104 [ 3162 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:53:16.415192 [ 3163 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:53:16.604359 [ 2688 ] {16719403-f799-4232-ad51-6931143fe25a} executeQuery: Code: 43. DB::Exception: Function toStartOfHour supports a 2nd argument (optional) that must be a valid time zone: In scope SELECT toStartOfHour(toDateTime('2017-12-31 00:00:00', 'UTC'), ''). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:60760) (comment: 01472_toBoundsOfInterval_disallow_empty_tz_field.sql) (in query: SELECT toStartOfHour(toDateTime('2017-12-31 00:00:00', 'UTC'), '');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000aad4b34 4. DB::FunctionDateOrDateTimeToDateTimeOrDateTime64::getReturnTypeImpl(std::vector> const&) const @ 0x00000000186b5a89 5. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000ccd376e 6. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000ccd3176 7. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000ccd4343 8. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000028399ff0 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000028367bce 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028366290 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283b62c9 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002835ae03 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000028359104 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000028357f0d 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002921bdcc 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&) @ 0x000000002941f313 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&) @ 0x0000000029419aef 18. ./contrib/llvm-project/libcxx/include/vector:432: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000029421f5d 19. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000029344c1b 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*) @ 0x0000000029b3703b 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 27. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 28. asan_thread_start(void*) @ 0x000000000aa43059 29. ? @ 0x00007f35aab92ac3 30. ? @ 0x00007f35aac24850 2025.09.09 14:53:16.615507 [ 2688 ] {16719403-f799-4232-ad51-6931143fe25a} TCPHandler: Code: 43. DB::Exception: Function toStartOfHour supports a 2nd argument (optional) that must be a valid time zone: In scope SELECT toStartOfHour(toDateTime('2017-12-31 00:00:00', 'UTC'), ''). (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000aad4b34 4. DB::FunctionDateOrDateTimeToDateTimeOrDateTime64::getReturnTypeImpl(std::vector> const&) const @ 0x00000000186b5a89 5. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000ccd376e 6. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000ccd3176 7. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000ccd4343 8. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000028399ff0 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000028367bce 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028366290 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283b62c9 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002835ae03 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000028359104 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000028357f0d 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002921bdcc 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&) @ 0x000000002941f313 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&) @ 0x0000000029419aef 18. ./contrib/llvm-project/libcxx/include/vector:432: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000029421f5d 19. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000029344c1b 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*) @ 0x0000000029b3703b 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 27. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 28. asan_thread_start(void*) @ 0x000000000aa43059 29. ? @ 0x00007f35aab92ac3 30. ? @ 0x00007f35aac24850 2025.09.09 14:53:16.750421 [ 3722 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 14:53:16.921076 [ 2688 ] {608db26e-26d4-4bb6-bc44-fadb5d0d5049} executeQuery: Code: 43. DB::Exception: Function toStartOfMinute supports a 2nd argument (optional) that must be a valid time zone: In scope SELECT toStartOfMinute(toDateTime('2017-12-31 00:00:00', 'UTC'), ''). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:60760) (comment: 01472_toBoundsOfInterval_disallow_empty_tz_field.sql) (in query: SELECT toStartOfMinute(toDateTime('2017-12-31 00:00:00', 'UTC'), '');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000aad4b34 4. DB::FunctionDateOrDateTimeToDateTimeOrDateTime64::getReturnTypeImpl(std::vector> const&) const @ 0x00000000186d7f69 5. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000ccd376e 6. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000ccd3176 7. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000ccd4343 8. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000028399ff0 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000028367bce 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028366290 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283b62c9 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002835ae03 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000028359104 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000028357f0d 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002921bdcc 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&) @ 0x000000002941f313 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&) @ 0x0000000029419aef 18. ./contrib/llvm-project/libcxx/include/vector:432: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000029421f5d 19. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000029344c1b 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*) @ 0x0000000029b3703b 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 27. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 28. asan_thread_start(void*) @ 0x000000000aa43059 29. ? @ 0x00007f35aab92ac3 30. ? @ 0x00007f35aac24850 2025.09.09 14:53:16.925551 [ 2688 ] {608db26e-26d4-4bb6-bc44-fadb5d0d5049} TCPHandler: Code: 43. DB::Exception: Function toStartOfMinute supports a 2nd argument (optional) that must be a valid time zone: In scope SELECT toStartOfMinute(toDateTime('2017-12-31 00:00:00', 'UTC'), ''). (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000aad4b34 4. DB::FunctionDateOrDateTimeToDateTimeOrDateTime64::getReturnTypeImpl(std::vector> const&) const @ 0x00000000186d7f69 5. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000ccd376e 6. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000ccd3176 7. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000ccd4343 8. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000028399ff0 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000028367bce 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028366290 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283b62c9 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002835ae03 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000028359104 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000028357f0d 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002921bdcc 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&) @ 0x000000002941f313 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&) @ 0x0000000029419aef 18. ./contrib/llvm-project/libcxx/include/vector:432: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000029421f5d 19. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000029344c1b 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*) @ 0x0000000029b3703b 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 27. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 28. asan_thread_start(void*) @ 0x000000000aa43059 29. ? @ 0x00007f35aab92ac3 30. ? @ 0x00007f35aac24850 2025.09.09 14:53:17.357515 [ 3182 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:53:17.514900 [ 3185 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:53:17.798009 [ 2688 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 14:53:18.359563 [ 3205 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:53:18.516964 [ 3210 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:53:18.811661 [ 3722 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 14:53:19.364290 [ 3222 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:53:19.519165 [ 3228 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:53:19.834523 [ 3722 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 14:53:20.439760 [ 2734 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:53:20.521364 [ 2738 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:53:20.953248 [ 4020 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 14:53:21.384834 [ 4025 ] {c594c7f6-8ae4-4571-a226-05aed4fee26c} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=13, jobs=2): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:59978) (comment: 00020_distinct_order_by_distributed.sql) (in query: SELECT DISTINCT `__table1`.`PredLastVisit` AS `x` FROM `test`.`visits` AS `__table1` ORDER BY `__table1`.`VisitID` ASC), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af80b71 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80746 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002c765aab 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:1197: ? @ 0x000000002c7602b8 8. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x000000002c75fc2b 9. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:0: DB::MergeTreeReaderWide::addStream(DB::ISerialization::SubstreamPath const&, String const&) @ 0x000000002c802c31 10. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:0: void std::__function::__policy_invoker::__call_impl const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x000000002c804a95 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000027a9e455 12. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:106: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x0000000027a9ea65 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:100: DB::MergeTreeReaderWide::addStreams(DB::NameAndTypePair const&, std::shared_ptr const&) @ 0x000000002c7fe815 14. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:0: DB::MergeTreeReaderWide::MergeTreeReaderWide(std::shared_ptr, DB::NamesAndTypesList, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*, DB::MarkCache*, DB::MarkRanges, DB::MergeTreeReaderSettings, std::map, std::allocator>>, std::function const&, int) @ 0x000000002c7fdeea 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) @ 0x000000002c5eb9c6 16. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWide.cpp:43: DB::MergeTreeDataPartWide::getReader(DB::NamesAndTypesList const&, std::shared_ptr const&, DB::MarkRanges const&, std::unordered_map, std::equal_to, std::allocator>> const&, DB::UncompressedCache*, DB::MarkCache*, std::shared_ptr const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) const @ 0x000000002c5e354e 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:44: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x000000002c82a56b 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:295: DB::MergeTreeReadPoolBase::createTask(std::shared_ptr, DB::MarkRanges, DB::MergeTreeReadTask*) const @ 0x000000002de9c234 19. ./build_docker/./src/Storages/MergeTree/MergeTreeReadPoolInOrder.cpp:72: DB::MergeTreeReadPoolInOrder::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x000000002deff671 20. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectAlgorithms.cpp:17: DB::MergeTreeInOrderSelectAlgorithm::getNewTask(DB::IMergeTreeReadPool&, DB::MergeTreeReadTask*) @ 0x000000002dea3919 21. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:0: DB::MergeTreeSelectProcessor::read() @ 0x000000002c8241d2 22. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000002de6d77a 23. ./build_docker/./src/Processors/ISource.cpp:0: DB::ISource::work() @ 0x000000002d3290a1 24. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 26. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:381: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000002d34bd35 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7eaf0 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001af8a79f 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 31. asan_thread_start(void*) @ 0x000000000aa43059 2025.09.09 14:53:21.404983 [ 4025 ] {c594c7f6-8ae4-4571-a226-05aed4fee26c} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=13, jobs=2): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af80b71 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80746 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002c765aab 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:1197: ? @ 0x000000002c7602b8 8. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x000000002c75fc2b 9. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:0: DB::MergeTreeReaderWide::addStream(DB::ISerialization::SubstreamPath const&, String const&) @ 0x000000002c802c31 10. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:0: void std::__function::__policy_invoker::__call_impl const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x000000002c804a95 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000027a9e455 12. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:106: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x0000000027a9ea65 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:100: DB::MergeTreeReaderWide::addStreams(DB::NameAndTypePair const&, std::shared_ptr const&) @ 0x000000002c7fe815 14. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:0: DB::MergeTreeReaderWide::MergeTreeReaderWide(std::shared_ptr, DB::NamesAndTypesList, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*, DB::MarkCache*, DB::MarkRanges, DB::MergeTreeReaderSettings, std::map, std::allocator>>, std::function const&, int) @ 0x000000002c7fdeea 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) @ 0x000000002c5eb9c6 16. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWide.cpp:43: DB::MergeTreeDataPartWide::getReader(DB::NamesAndTypesList const&, std::shared_ptr const&, DB::MarkRanges const&, std::unordered_map, std::equal_to, std::allocator>> const&, DB::UncompressedCache*, DB::MarkCache*, std::shared_ptr const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) const @ 0x000000002c5e354e 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:44: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x000000002c82a56b 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:295: DB::MergeTreeReadPoolBase::createTask(std::shared_ptr, DB::MarkRanges, DB::MergeTreeReadTask*) const @ 0x000000002de9c234 19. ./build_docker/./src/Storages/MergeTree/MergeTreeReadPoolInOrder.cpp:72: DB::MergeTreeReadPoolInOrder::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x000000002deff671 20. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectAlgorithms.cpp:17: DB::MergeTreeInOrderSelectAlgorithm::getNewTask(DB::IMergeTreeReadPool&, DB::MergeTreeReadTask*) @ 0x000000002dea3919 21. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:0: DB::MergeTreeSelectProcessor::read() @ 0x000000002c8241d2 22. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000002de6d77a 23. ./build_docker/./src/Processors/ISource.cpp:0: DB::ISource::work() @ 0x000000002d3290a1 24. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 26. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:381: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000002d34bd35 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7eaf0 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001af8a79f 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 31. asan_thread_start(void*) @ 0x000000000aa43059 2025.09.09 14:53:21.435646 [ 2688 ] {29e1d938-6708-40ee-9f74-b45e442157ce} executeQuery: Code: 439. DB::Exception: Received from 127.0.0.2:9000. DB::Exception: Cannot schedule a task: fault injected (threads=13, jobs=2): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder). Stack trace: 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af80b71 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80746 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002c765aab 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:1197: ? @ 0x000000002c7602b8 8. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x000000002c75fc2b 9. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:0: DB::MergeTreeReaderWide::addStream(DB::ISerialization::SubstreamPath const&, String const&) @ 0x000000002c802c31 10. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:0: void std::__function::__policy_invoker::__call_impl const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x000000002c804a95 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000027a9e455 12. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:106: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x0000000027a9ea65 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:100: DB::MergeTreeReaderWide::addStreams(DB::NameAndTypePair const&, std::shared_ptr const&) @ 0x000000002c7fe815 14. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:0: DB::MergeTreeReaderWide::MergeTreeReaderWide(std::shared_ptr, DB::NamesAndTypesList, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*, DB::MarkCache*, DB::MarkRanges, DB::MergeTreeReaderSettings, std::map, std::allocator>>, std::function const&, int) @ 0x000000002c7fdeea 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) @ 0x000000002c5eb9c6 16. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWide.cpp:43: DB::MergeTreeDataPartWide::getReader(DB::NamesAndTypesList const&, std::shared_ptr const&, DB::MarkRanges const&, std::unordered_map, std::equal_to, std::allocator>> const&, DB::UncompressedCache*, DB::MarkCache*, std::shared_ptr const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) const @ 0x000000002c5e354e 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:44: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x000000002c82a56b 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:295: DB::MergeTreeReadPoolBase::createTask(std::shared_ptr, DB::MarkRanges, DB::MergeTreeReadTask*) const @ 0x000000002de9c234 19. ./build_docker/./src/Storages/MergeTree/MergeTreeReadPoolInOrder.cpp:72: DB::MergeTreeReadPoolInOrder::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x000000002deff671 20. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectAlgorithms.cpp:17: DB::MergeTreeInOrderSelectAlgorithm::getNewTask(DB::IMergeTreeReadPool&, DB::MergeTreeReadTask*) @ 0x000000002dea3919 21. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:0: DB::MergeTreeSelectProcessor::read() @ 0x000000002c8241d2 22. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000002de6d77a 23. ./build_docker/./src/Processors/ISource.cpp:0: DB::ISource::work() @ 0x000000002d3290a1 24. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 26. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:381: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000002d34bd35 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7eaf0 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001af8a79f 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 31. asan_thread_start(void*) @ 0x000000000aa43059 : While executing Remote. (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:34120) (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. ./contrib/llvm-project/libcxx/include/string:1499: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x000000001aeb974e 3. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::Connection::receiveException() const @ 0x000000002cee6c6a 4. ./build_docker/./src/Client/Connection.cpp:0: DB::Connection::receivePacket() @ 0x000000002cef780e 5. ./build_docker/./src/Client/PacketReceiver.cpp:0: DB::PacketReceiver::Task::run(std::function, std::function) @ 0x000000002cf9767e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000278ab436 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000278aaa44 8. ./contrib/boost/boost/context/fiber_ucontext.hpp:82: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x00000000278a8394 2025.09.09 14:53:21.442482 [ 2758 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:53:21.442526 [ 2688 ] {29e1d938-6708-40ee-9f74-b45e442157ce} TCPHandler: Code: 439. DB::Exception: Received from 127.0.0.2:9000. DB::Exception: Cannot schedule a task: fault injected (threads=13, jobs=2): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder). Stack trace: 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af80b71 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80746 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002c765aab 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:1197: ? @ 0x000000002c7602b8 8. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x000000002c75fc2b 9. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:0: DB::MergeTreeReaderWide::addStream(DB::ISerialization::SubstreamPath const&, String const&) @ 0x000000002c802c31 10. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:0: void std::__function::__policy_invoker::__call_impl const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x000000002c804a95 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000027a9e455 12. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:106: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x0000000027a9ea65 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:100: DB::MergeTreeReaderWide::addStreams(DB::NameAndTypePair const&, std::shared_ptr const&) @ 0x000000002c7fe815 14. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:0: DB::MergeTreeReaderWide::MergeTreeReaderWide(std::shared_ptr, DB::NamesAndTypesList, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*, DB::MarkCache*, DB::MarkRanges, DB::MergeTreeReaderSettings, std::map, std::allocator>>, std::function const&, int) @ 0x000000002c7fdeea 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) @ 0x000000002c5eb9c6 16. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWide.cpp:43: DB::MergeTreeDataPartWide::getReader(DB::NamesAndTypesList const&, std::shared_ptr const&, DB::MarkRanges const&, std::unordered_map, std::equal_to, std::allocator>> const&, DB::UncompressedCache*, DB::MarkCache*, std::shared_ptr const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) const @ 0x000000002c5e354e 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:44: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x000000002c82a56b 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:295: DB::MergeTreeReadPoolBase::createTask(std::shared_ptr, DB::MarkRanges, DB::MergeTreeReadTask*) const @ 0x000000002de9c234 19. ./build_docker/./src/Storages/MergeTree/MergeTreeReadPoolInOrder.cpp:72: DB::MergeTreeReadPoolInOrder::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x000000002deff671 20. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectAlgorithms.cpp:17: DB::MergeTreeInOrderSelectAlgorithm::getNewTask(DB::IMergeTreeReadPool&, DB::MergeTreeReadTask*) @ 0x000000002dea3919 21. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:0: DB::MergeTreeSelectProcessor::read() @ 0x000000002c8241d2 22. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000002de6d77a 23. ./build_docker/./src/Processors/ISource.cpp:0: DB::ISource::work() @ 0x000000002d3290a1 24. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 26. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:381: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000002d34bd35 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7eaf0 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001af8a79f 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 31. asan_thread_start(void*) @ 0x000000000aa43059 : 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. ./contrib/llvm-project/libcxx/include/string:1499: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x000000001aeb974e 3. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::Connection::receiveException() const @ 0x000000002cee6c6a 4. ./build_docker/./src/Client/Connection.cpp:0: DB::Connection::receivePacket() @ 0x000000002cef780e 5. ./build_docker/./src/Client/PacketReceiver.cpp:0: DB::PacketReceiver::Task::run(std::function, std::function) @ 0x000000002cf9767e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000278ab436 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000278aaa44 8. ./contrib/boost/boost/context/fiber_ucontext.hpp:82: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x00000000278a8394 2025.09.09 14:53:21.537287 [ 2749 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:53:22.037970 [ 4025 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 14:53:22.172614 [ 3339 ] {55ad5dcc-cc4b-49f6-8a6a-4cd08eafcd97::all_1_1_0_3} MutatePlainMergeTreeTask: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=5, jobs=5). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:53:22.176058 [ 4016 ] {baa7573d-bfa1-4c9d-9e52-0b7108eaf001} executeQuery: Code: 341. DB::Exception: Exception happened during execution of mutation 'mutation_3.txt' with part 'all_1_1_0' reason: 'Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=5, jobs=5). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.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.10505.altinitytest (altinity build)) (from [::1]:34162) (comment: 03148_mutations_virtual_columns.sql) (in query: ALTER TABLE t_mut_virtuals UPDATE s = _part WHERE 1;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&&, String&, String&) @ 0x000000002c76d4c6 4. ./build_docker/./src/Storages/MergeTree/MergeTreeMutationStatus.cpp:26: DB::checkMutationStatus(std::optional&, std::set, std::allocator> const&) @ 0x000000002c76d210 5. ./build_docker/./src/Storages/StorageMergeTree.cpp:0: DB::StorageMergeTree::waitForMutation(long, String const&, bool) @ 0x000000002cbbc805 6. ./contrib/llvm-project/libcxx/include/string:1499: DB::StorageMergeTree::mutate(DB::MutationCommands const&, std::shared_ptr) @ 0x000000002cbbe409 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000029174a1c 8. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x0000000029170711 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b382fc 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 14:53:22.177004 [ 3339 ] {55ad5dcc-cc4b-49f6-8a6a-4cd08eafcd97::all_1_1_0_3} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=5, jobs=5). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af819ed 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80746 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d34b5ca 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:306: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349fbb 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:381: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000002d34bd35 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7eaf0 10. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001af8a79f 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 13. asan_thread_start(void*) @ 0x000000000aa43059 14. ? @ 0x00007f35aab92ac3 15. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:53:22.254149 [ 4016 ] {baa7573d-bfa1-4c9d-9e52-0b7108eaf001} TCPHandler: Code: 341. DB::Exception: Exception happened during execution of mutation 'mutation_3.txt' with part 'all_1_1_0' reason: 'Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=5, jobs=5). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&&, String&, String&) @ 0x000000002c76d4c6 4. ./build_docker/./src/Storages/MergeTree/MergeTreeMutationStatus.cpp:26: DB::checkMutationStatus(std::optional&, std::set, std::allocator> const&) @ 0x000000002c76d210 5. ./build_docker/./src/Storages/StorageMergeTree.cpp:0: DB::StorageMergeTree::waitForMutation(long, String const&, bool) @ 0x000000002cbbc805 6. ./contrib/llvm-project/libcxx/include/string:1499: DB::StorageMergeTree::mutate(DB::MutationCommands const&, std::shared_ptr) @ 0x000000002cbbe409 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000029174a1c 8. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x0000000029170711 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b382fc 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 14:53:22.262797 [ 5360 ] {75bf9a7a-a4bc-4027-83dd-4a7fbeeac99d} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=7, jobs=7). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:34186) (comment: 00084_external_aggregation.sql) (in query: SELECT URL, uniq(SearchPhrase) AS u FROM test.hits GROUP BY URL ORDER BY u DESC, URL LIMIT 10;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af80b71 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80746 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d34b5ca 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:306: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349fbb 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:381: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000002d34bd35 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7eaf0 10. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001af8a79f 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 13. asan_thread_start(void*) @ 0x000000000aa43059 14. ? @ 0x00007f35aab92ac3 15. ? @ 0x00007f35aac24850 2025.09.09 14:53:22.269137 [ 5360 ] {75bf9a7a-a4bc-4027-83dd-4a7fbeeac99d} 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af80b71 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80746 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d34b5ca 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:306: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349fbb 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:381: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000002d34bd35 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7eaf0 10. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001af8a79f 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 13. asan_thread_start(void*) @ 0x000000000aa43059 14. ? @ 0x00007f35aab92ac3 15. ? @ 0x00007f35aac24850 2025.09.09 14:53:22.285717 [ 3329 ] {55ad5dcc-cc4b-49f6-8a6a-4cd08eafcd97::all_1_1_0_3} MutatePlainMergeTreeTask: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=8, jobs=2). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:53:22.302481 [ 3329 ] {55ad5dcc-cc4b-49f6-8a6a-4cd08eafcd97::all_1_1_0_3} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=8, jobs=2). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af80b71 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80746 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d34b5ca 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000002d3486e4 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000002d34827b 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002d36bcf7 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 12. asan_thread_start(void*) @ 0x000000000aa43059 13. ? @ 0x00007f35aab92ac3 14. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:53:22.439334 [ 3334 ] {55ad5dcc-cc4b-49f6-8a6a-4cd08eafcd97::all_1_1_0_3} MutatePlainMergeTreeTask: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=1, jobs=1). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:53:22.441113 [ 3334 ] {55ad5dcc-cc4b-49f6-8a6a-4cd08eafcd97::all_1_1_0_3} 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af80b71 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80746 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d34b5ca 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000002d3486e4 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000002d34827b 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002d36bcf7 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 12. asan_thread_start(void*) @ 0x000000000aa43059 13. ? @ 0x00007f35aab92ac3 14. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:53:22.444406 [ 2775 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:53:22.518393 [ 3330 ] {55ad5dcc-cc4b-49f6-8a6a-4cd08eafcd97::all_1_1_0_3} MutatePlainMergeTreeTask: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=6, jobs=6). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:53:22.520184 [ 3330 ] {55ad5dcc-cc4b-49f6-8a6a-4cd08eafcd97::all_1_1_0_3} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=6, jobs=6). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af80b71 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80746 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d34b5ca 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000002d3486e4 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000002d34827b 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002d36bcf7 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 12. asan_thread_start(void*) @ 0x000000000aa43059 13. ? @ 0x00007f35aab92ac3 14. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:53:22.539222 [ 2776 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:53:23.034756 [ 2686 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 14:53:23.446510 [ 2799 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:53:23.541387 [ 2801 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:53:24.043136 [ 5360 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 14:53:24.130513 [ 3336 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {1e64423d-b43b-45ea-b85e-a97c07ea6431::202509_1_30_6}: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=13, jobs=0). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af80b71 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80746 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002c765aab 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:1197: ? @ 0x000000002c7602b8 8. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x000000002c75fc2b 9. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:0: DB::MergeTreeReaderCompact::MergeTreeReaderCompact(std::shared_ptr, DB::NamesAndTypesList, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*, DB::MarkCache*, DB::MarkRanges, DB::MergeTreeReaderSettings, std::map, std::allocator>>, std::function const&, int) @ 0x000000002c7aee03 10. ./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.h:16: DB::MergeTreeReaderCompactSingleBuffer::MergeTreeReaderCompactSingleBuffer&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int&&) @ 0x000000002c5d6d21 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::MergeTreeDataPartCompact::getReader(DB::NamesAndTypesList const&, std::shared_ptr const&, DB::MarkRanges const&, std::unordered_map, std::equal_to, std::allocator>> const&, DB::UncompressedCache*, DB::MarkCache*, std::shared_ptr const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) const @ 0x000000002c5d1037 12. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:169: DB::MergeTreeSequentialSource::MergeTreeSequentialSource(DB::MergeTreeSequentialSourceType, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::vector>, std::optional, bool, bool, bool) @ 0x000000002c80c330 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:35: DB::MergeTreeSequentialSource* std::construct_at[abi:v15007] const&, std::shared_ptr&, std::shared_ptr&, std::vector>&, std::optional, bool, bool&, bool&, DB::MergeTreeSequentialSource*>(DB::MergeTreeSequentialSource*, DB::MergeTreeSequentialSourceType&, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr&, std::shared_ptr&, std::vector>&, std::optional&&, bool&&, bool&, bool&) @ 0x000000002c81320f 14. ./contrib/llvm-project/libcxx/include/__memory/allocator_traits.h:298: DB::createMergeTreeSequentialSource(DB::MergeTreeSequentialSourceType, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::vector>, std::optional, std::shared_ptr>, bool, bool, bool) @ 0x000000002c810812 15. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1136: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::createMergedStream() @ 0x000000002c3dd079 16. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() @ 0x000000002c3d6516 17. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:534: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x000000002c3e2799 18. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::execute() @ 0x000000002c3ef3fe 19. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:0: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000002cc2f4c0 20. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000002c427f28 21. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000002c429675 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7eaf0 23. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001af8a79f 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 26. asan_thread_start(void*) @ 0x000000000aa43059 27. ? @ 0x00007f35aab92ac3 28. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:53:24.448620 [ 2829 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:53:24.543540 [ 2830 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:53:25.122051 [ 5360 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 14:53:25.450732 [ 2854 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:53:25.545544 [ 2861 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:53:26.109708 [ 4025 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 14:53:26.395999 [ 5360 ] {d5bc487c-8bee-4bb3-b7e1-693a5e6fa9bc} 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.10505.altinitytest (altinity build)) (from [::1]:34282) (comment: 00150_quantiles_timing_precision.sql) (in query: SELECT CounterID, quantileTiming(0.5)(SendTiming) AS qt, least(30000, quantileExact(0.5)(SendTiming)) AS qe, count() AS c, round(abs(qt - qe) / greatest(qt, qe) AS diff, 3) AS rounded_diff FROM test.hits WHERE SendTiming != -1 GROUP BY CounterID HAVING diff != 0 ORDER BY diff DESC 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af819ed 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80746 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d34b5ca 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000002d3486e4 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000002d34827b 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002d36bcf7 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 12. asan_thread_start(void*) @ 0x000000000aa43059 13. ? @ 0x00007f35aab92ac3 14. ? @ 0x00007f35aac24850 2025.09.09 14:53:26.401783 [ 5360 ] {d5bc487c-8bee-4bb3-b7e1-693a5e6fa9bc} 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af819ed 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80746 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d34b5ca 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000002d3486e4 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000002d34827b 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002d36bcf7 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 12. asan_thread_start(void*) @ 0x000000000aa43059 13. ? @ 0x00007f35aab92ac3 14. ? @ 0x00007f35aac24850 2025.09.09 14:53:26.453012 [ 2877 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:53:26.547656 [ 2879 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:53:27.220596 [ 4016 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 14:53:27.454965 [ 2899 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:53:27.472711 [ 2686 ] {12197920-3c8d-47ec-9ba5-cdaa6b98d992} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=13, jobs=0): While executing MergeTreeSelect(pool: ReadPool, algorithm: Thread). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:34312) (comment: 00021_1_select_with_in.sql) (in query: select sum(Sign) from test.visits where CounterID in (942285);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af80b71 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80746 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002c765aab 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:1197: ? @ 0x000000002c7602b8 8. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x000000002c75fc2b 9. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:0: DB::MergeTreeReaderWide::addStream(DB::ISerialization::SubstreamPath const&, String const&) @ 0x000000002c802c31 10. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:0: void std::__function::__policy_invoker::__call_impl const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x000000002c804a95 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000027a9e455 12. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:106: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x0000000027a9ea65 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:100: DB::MergeTreeReaderWide::addStreams(DB::NameAndTypePair const&, std::shared_ptr const&) @ 0x000000002c7fe815 14. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:0: DB::MergeTreeReaderWide::MergeTreeReaderWide(std::shared_ptr, DB::NamesAndTypesList, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*, DB::MarkCache*, DB::MarkRanges, DB::MergeTreeReaderSettings, std::map, std::allocator>>, std::function const&, int) @ 0x000000002c7fdeea 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) @ 0x000000002c5eb9c6 16. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWide.cpp:43: DB::MergeTreeDataPartWide::getReader(DB::NamesAndTypesList const&, std::shared_ptr const&, DB::MarkRanges const&, std::unordered_map, std::equal_to, std::allocator>> const&, DB::UncompressedCache*, DB::MarkCache*, std::shared_ptr const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) const @ 0x000000002c5e354e 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:44: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x000000002c82a56b 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:295: DB::MergeTreeReadPoolBase::createTask(std::shared_ptr, DB::MarkRanges, DB::MergeTreeReadTask*) const @ 0x000000002de9c5f2 19. ./build_docker/./src/Storages/MergeTree/MergeTreeReadPool.cpp:144: DB::MergeTreeReadPool::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x000000002def1bcc 20. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:0: DB::MergeTreeSelectProcessor::read() @ 0x000000002c8241d2 21. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000002de6d77a 22. ./build_docker/./src/Processors/ISource.cpp:0: DB::ISource::work() @ 0x000000002d3290a1 23. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:381: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000002d34bd35 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7eaf0 27. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001af8a79f 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 30. asan_thread_start(void*) @ 0x000000000aa43059 31. ? @ 0x00007f35aab92ac3 2025.09.09 14:53:27.495486 [ 2686 ] {12197920-3c8d-47ec-9ba5-cdaa6b98d992} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=13, jobs=0): While executing MergeTreeSelect(pool: ReadPool, algorithm: Thread). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af80b71 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80746 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002c765aab 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:1197: ? @ 0x000000002c7602b8 8. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x000000002c75fc2b 9. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:0: DB::MergeTreeReaderWide::addStream(DB::ISerialization::SubstreamPath const&, String const&) @ 0x000000002c802c31 10. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:0: void std::__function::__policy_invoker::__call_impl const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x000000002c804a95 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000027a9e455 12. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:106: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x0000000027a9ea65 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:100: DB::MergeTreeReaderWide::addStreams(DB::NameAndTypePair const&, std::shared_ptr const&) @ 0x000000002c7fe815 14. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:0: DB::MergeTreeReaderWide::MergeTreeReaderWide(std::shared_ptr, DB::NamesAndTypesList, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*, DB::MarkCache*, DB::MarkRanges, DB::MergeTreeReaderSettings, std::map, std::allocator>>, std::function const&, int) @ 0x000000002c7fdeea 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) @ 0x000000002c5eb9c6 16. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWide.cpp:43: DB::MergeTreeDataPartWide::getReader(DB::NamesAndTypesList const&, std::shared_ptr const&, DB::MarkRanges const&, std::unordered_map, std::equal_to, std::allocator>> const&, DB::UncompressedCache*, DB::MarkCache*, std::shared_ptr const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) const @ 0x000000002c5e354e 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:44: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x000000002c82a56b 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:295: DB::MergeTreeReadPoolBase::createTask(std::shared_ptr, DB::MarkRanges, DB::MergeTreeReadTask*) const @ 0x000000002de9c5f2 19. ./build_docker/./src/Storages/MergeTree/MergeTreeReadPool.cpp:144: DB::MergeTreeReadPool::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x000000002def1bcc 20. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:0: DB::MergeTreeSelectProcessor::read() @ 0x000000002c8241d2 21. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000002de6d77a 22. ./build_docker/./src/Processors/ISource.cpp:0: DB::ISource::work() @ 0x000000002d3290a1 23. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:381: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000002d34bd35 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7eaf0 27. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001af8a79f 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 30. asan_thread_start(void*) @ 0x000000000aa43059 31. ? @ 0x00007f35aab92ac3 2025.09.09 14:53:27.549643 [ 2900 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:53:28.042167 [ 5771 ] {78d6aa18-3754-4886-9892-8a66cf15eae9} void DB::ParallelParsingInputFormat::onBackgroundException(): Code: 27. DB::Exception: Cannot parse input: expected '{' before: 'null}}}': (while reading the value of nested key merged_by): (while reading the value of nested key pull_request): (while reading the value of key payload): (at row 1) . (CANNOT_PARSE_INPUT_ASSERTION_FAILED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::throwAtAssertionFailed(char const*, DB::ReadBuffer&) @ 0x000000001aeb2ed5 4. ./src/IO/ReadBuffer.h:114: void DB::SerializationTuple::deserializeTextJSONImpl(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x0000000027c34600 5. ./build_docker/./src/DataTypes/Serializations/SerializationTuple.cpp:0: void DB::SerializationTuple::deserializeTextJSONImpl(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const::'lambda'(DB::IColumn&, unsigned long)::operator()(DB::IColumn&, unsigned long) const @ 0x0000000027c3b82f 6. ./build_docker/./src/DataTypes/Serializations/SerializationTuple.cpp:0: void DB::SerializationTuple::deserializeTextJSONImpl(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const::'lambda'()::operator()() const @ 0x0000000027c3a5d4 7. ./build_docker/./src/DataTypes/Serializations/SerializationTuple.cpp:89: void DB::SerializationTuple::deserializeTextJSONImpl(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x0000000027c34056 8. ./build_docker/./src/DataTypes/Serializations/SerializationTuple.cpp:0: void DB::SerializationTuple::deserializeTextJSONImpl(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const::'lambda'(DB::IColumn&, unsigned long)::operator()(DB::IColumn&, unsigned long) const @ 0x0000000027c3b82f 9. ./build_docker/./src/DataTypes/Serializations/SerializationTuple.cpp:0: void DB::SerializationTuple::deserializeTextJSONImpl(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const::'lambda'()::operator()() const @ 0x0000000027c3a5d4 10. ./build_docker/./src/DataTypes/Serializations/SerializationTuple.cpp:89: void DB::SerializationTuple::deserializeTextJSONImpl(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x0000000027c34056 11. ./build_docker/./src/Formats/JSONUtils.cpp:300: DB::JSONUtils::readField(DB::ReadBuffer&, DB::IColumn&, std::shared_ptr const&, std::shared_ptr const&, String const&, DB::FormatSettings const&, bool) @ 0x000000002d5f1d77 12. ./build_docker/./src/Processors/Formats/Impl/JSONEachRowRowInputFormat.cpp:139: DB::JSONEachRowRowInputFormat::readField(unsigned long, std::vector::mutable_ptr, std::allocator::mutable_ptr>>&) @ 0x000000002d620468 13. ./build_docker/./src/Processors/Formats/Impl/JSONEachRowRowInputFormat.cpp:0: DB::JSONEachRowRowInputFormat::readJSONObject(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&) @ 0x000000002d6209fa 14. ./src/Processors/ISource.h:41: DB::JSONEachRowRowInputFormat::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x000000002d6214a7 15. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:0: DB::IRowInputFormat::read() @ 0x000000002d46d965 16. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000002d37a746 17. ./src/Processors/Chunk.h:110: DB::ISource::tryGenerate() @ 0x000000002d329c18 18. ./build_docker/./src/Processors/ISource.cpp:0: DB::ISource::work() @ 0x000000002d3290a1 19. ./src/Processors/Formats/Impl/ParallelParsingInputFormat.h:0: DB::ParallelParsingInputFormat::InternalParser::getChunk() @ 0x000000002d6fa5e9 20. ./contrib/llvm-project/libcxx/include/vector:961: DB::ParallelParsingInputFormat::parserThreadFunction(std::shared_ptr, unsigned long) @ 0x000000002d6f7281 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7eaf0 22. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001af8a79f 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 25. asan_thread_start(void*) @ 0x000000000aa43059 26. ? @ 0x00007f35aab92ac3 27. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:53:28.054825 [ 4025 ] {78d6aa18-3754-4886-9892-8a66cf15eae9} executeQuery: Code: 27. DB::Exception: Cannot parse input: expected '{' before: 'null}}}': (while reading the value of nested key merged_by): (while reading the value of nested key pull_request): (while reading the value of key payload): (at row 1) : While executing ParallelParsingBlockInputFormat. (CANNOT_PARSE_INPUT_ASSERTION_FAILED) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:34308) (comment: 02573_insert_null_as_default_null_as_empty_nested.sql) (in query: select * from format(JSONEachRow, 'payload Tuple(pull_request Tuple(merged_by Tuple(login String)))', '{"payload" : {"pull_request": {"merged_by": null}}}') settings input_format_null_as_default=0;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::throwAtAssertionFailed(char const*, DB::ReadBuffer&) @ 0x000000001aeb2ed5 4. ./src/IO/ReadBuffer.h:114: void DB::SerializationTuple::deserializeTextJSONImpl(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x0000000027c34600 5. ./build_docker/./src/DataTypes/Serializations/SerializationTuple.cpp:0: void DB::SerializationTuple::deserializeTextJSONImpl(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const::'lambda'(DB::IColumn&, unsigned long)::operator()(DB::IColumn&, unsigned long) const @ 0x0000000027c3b82f 6. ./build_docker/./src/DataTypes/Serializations/SerializationTuple.cpp:0: void DB::SerializationTuple::deserializeTextJSONImpl(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const::'lambda'()::operator()() const @ 0x0000000027c3a5d4 7. ./build_docker/./src/DataTypes/Serializations/SerializationTuple.cpp:89: void DB::SerializationTuple::deserializeTextJSONImpl(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x0000000027c34056 8. ./build_docker/./src/DataTypes/Serializations/SerializationTuple.cpp:0: void DB::SerializationTuple::deserializeTextJSONImpl(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const::'lambda'(DB::IColumn&, unsigned long)::operator()(DB::IColumn&, unsigned long) const @ 0x0000000027c3b82f 9. ./build_docker/./src/DataTypes/Serializations/SerializationTuple.cpp:0: void DB::SerializationTuple::deserializeTextJSONImpl(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const::'lambda'()::operator()() const @ 0x0000000027c3a5d4 10. ./build_docker/./src/DataTypes/Serializations/SerializationTuple.cpp:89: void DB::SerializationTuple::deserializeTextJSONImpl(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x0000000027c34056 11. ./build_docker/./src/Formats/JSONUtils.cpp:300: DB::JSONUtils::readField(DB::ReadBuffer&, DB::IColumn&, std::shared_ptr const&, std::shared_ptr const&, String const&, DB::FormatSettings const&, bool) @ 0x000000002d5f1d77 12. ./build_docker/./src/Processors/Formats/Impl/JSONEachRowRowInputFormat.cpp:139: DB::JSONEachRowRowInputFormat::readField(unsigned long, std::vector::mutable_ptr, std::allocator::mutable_ptr>>&) @ 0x000000002d620468 13. ./build_docker/./src/Processors/Formats/Impl/JSONEachRowRowInputFormat.cpp:0: DB::JSONEachRowRowInputFormat::readJSONObject(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&) @ 0x000000002d6209fa 14. ./src/Processors/ISource.h:41: DB::JSONEachRowRowInputFormat::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x000000002d6214a7 15. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:0: DB::IRowInputFormat::read() @ 0x000000002d46d965 16. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000002d37a746 17. ./src/Processors/Chunk.h:110: DB::ISource::tryGenerate() @ 0x000000002d329c18 18. ./build_docker/./src/Processors/ISource.cpp:0: DB::ISource::work() @ 0x000000002d3290a1 19. ./src/Processors/Formats/Impl/ParallelParsingInputFormat.h:0: DB::ParallelParsingInputFormat::InternalParser::getChunk() @ 0x000000002d6fa5e9 20. ./contrib/llvm-project/libcxx/include/vector:961: DB::ParallelParsingInputFormat::parserThreadFunction(std::shared_ptr, unsigned long) @ 0x000000002d6f7281 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7eaf0 22. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001af8a79f 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 25. asan_thread_start(void*) @ 0x000000000aa43059 26. ? @ 0x00007f35aab92ac3 27. ? @ 0x00007f35aac24850 2025.09.09 14:53:28.056910 [ 4025 ] {78d6aa18-3754-4886-9892-8a66cf15eae9} TCPHandler: Code: 27. DB::Exception: Cannot parse input: expected '{' before: 'null}}}': (while reading the value of nested key merged_by): (while reading the value of nested key pull_request): (while reading the value of key payload): (at row 1) : While executing ParallelParsingBlockInputFormat. (CANNOT_PARSE_INPUT_ASSERTION_FAILED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::throwAtAssertionFailed(char const*, DB::ReadBuffer&) @ 0x000000001aeb2ed5 4. ./src/IO/ReadBuffer.h:114: void DB::SerializationTuple::deserializeTextJSONImpl(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x0000000027c34600 5. ./build_docker/./src/DataTypes/Serializations/SerializationTuple.cpp:0: void DB::SerializationTuple::deserializeTextJSONImpl(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const::'lambda'(DB::IColumn&, unsigned long)::operator()(DB::IColumn&, unsigned long) const @ 0x0000000027c3b82f 6. ./build_docker/./src/DataTypes/Serializations/SerializationTuple.cpp:0: void DB::SerializationTuple::deserializeTextJSONImpl(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const::'lambda'()::operator()() const @ 0x0000000027c3a5d4 7. ./build_docker/./src/DataTypes/Serializations/SerializationTuple.cpp:89: void DB::SerializationTuple::deserializeTextJSONImpl(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x0000000027c34056 8. ./build_docker/./src/DataTypes/Serializations/SerializationTuple.cpp:0: void DB::SerializationTuple::deserializeTextJSONImpl(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const::'lambda'(DB::IColumn&, unsigned long)::operator()(DB::IColumn&, unsigned long) const @ 0x0000000027c3b82f 9. ./build_docker/./src/DataTypes/Serializations/SerializationTuple.cpp:0: void DB::SerializationTuple::deserializeTextJSONImpl(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const::'lambda'()::operator()() const @ 0x0000000027c3a5d4 10. ./build_docker/./src/DataTypes/Serializations/SerializationTuple.cpp:89: void DB::SerializationTuple::deserializeTextJSONImpl(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x0000000027c34056 11. ./build_docker/./src/Formats/JSONUtils.cpp:300: DB::JSONUtils::readField(DB::ReadBuffer&, DB::IColumn&, std::shared_ptr const&, std::shared_ptr const&, String const&, DB::FormatSettings const&, bool) @ 0x000000002d5f1d77 12. ./build_docker/./src/Processors/Formats/Impl/JSONEachRowRowInputFormat.cpp:139: DB::JSONEachRowRowInputFormat::readField(unsigned long, std::vector::mutable_ptr, std::allocator::mutable_ptr>>&) @ 0x000000002d620468 13. ./build_docker/./src/Processors/Formats/Impl/JSONEachRowRowInputFormat.cpp:0: DB::JSONEachRowRowInputFormat::readJSONObject(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&) @ 0x000000002d6209fa 14. ./src/Processors/ISource.h:41: DB::JSONEachRowRowInputFormat::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x000000002d6214a7 15. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:0: DB::IRowInputFormat::read() @ 0x000000002d46d965 16. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000002d37a746 17. ./src/Processors/Chunk.h:110: DB::ISource::tryGenerate() @ 0x000000002d329c18 18. ./build_docker/./src/Processors/ISource.cpp:0: DB::ISource::work() @ 0x000000002d3290a1 19. ./src/Processors/Formats/Impl/ParallelParsingInputFormat.h:0: DB::ParallelParsingInputFormat::InternalParser::getChunk() @ 0x000000002d6fa5e9 20. ./contrib/llvm-project/libcxx/include/vector:961: DB::ParallelParsingInputFormat::parserThreadFunction(std::shared_ptr, unsigned long) @ 0x000000002d6f7281 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7eaf0 22. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001af8a79f 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 25. asan_thread_start(void*) @ 0x000000000aa43059 26. ? @ 0x00007f35aab92ac3 27. ? @ 0x00007f35aac24850 2025.09.09 14:53:28.211457 [ 5360 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 14:53:28.457004 [ 2914 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:53:28.551716 [ 2923 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:53:28.782220 [ 4025 ] {a040501a-a97e-4e8b-9524-2d2846fad5a9} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=764, jobs=721). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:34308) (comment: 02573_insert_null_as_default_null_as_empty_nested.sql) (in query: select * from format(JSONEachRow, 'payload Map(String, String)', '{"payload" : {}}') settings input_format_null_as_default=1;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af872f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af7b2d1 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af7c3f3 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d36920d 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000002d369e5f 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processOrdinaryQuery() @ 0x000000002d18af7b 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d17644a 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 15. asan_thread_start(void*) @ 0x000000000aa43059 16. ? @ 0x00007f35aab92ac3 17. ? @ 0x00007f35aac24850 2025.09.09 14:53:28.783274 [ 4025 ] {a040501a-a97e-4e8b-9524-2d2846fad5a9} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=764, jobs=721). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af872f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af7b2d1 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af7c3f3 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d36920d 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000002d369e5f 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processOrdinaryQuery() @ 0x000000002d18af7b 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d17644a 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 15. asan_thread_start(void*) @ 0x000000000aa43059 16. ? @ 0x00007f35aab92ac3 17. ? @ 0x00007f35aac24850 2025.09.09 14:53:29.215538 [ 5360 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 14:53:29.459448 [ 2934 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:53:29.555057 [ 2937 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:53:30.271907 [ 4020 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 14:53:30.461627 [ 2954 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:53:30.567497 [ 2958 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:53:31.242472 [ 5360 ] {82c8dad3-e26d-422e-a985-6e7396038e4e} executeQuery: Code: 43. DB::Exception: Nested type Tuple() cannot be inside Nullable type. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:55868) (comment: 02891_empty_tuple.sql) (in query: CREATE TABLE x (`i` Nullable(Tuple)) ENGINE = MergeTree ORDER BY tuple() SETTINGS index_granularity = 20685, min_bytes_for_wide_part = 232105235, ratio_of_defaults_for_sparse_serialization = 0.07411396503448486, replace_long_file_name_to_hash = true, max_file_name_length = 30, min_bytes_for_full_part_storage = 249270319, compact_parts_max_bytes_to_buffer = 433263342, compact_parts_max_granules_to_buffer = 20, compact_parts_merge_max_bytes_to_prefetch_part = 9622859, merge_max_block_size = 2313, old_parts_lifetime = 151., prefer_fetch_merged_part_size_threshold = 10737418240, vertical_merge_algorithm_min_rows_to_activate = 1000000, vertical_merge_algorithm_min_columns_to_activate = 100, min_merge_bytes_to_use_direct_io = 10737418240, index_granularity_bytes = 7489618, concurrent_part_removal_threshold = 0, allow_vertical_merges_from_compact_to_wide_parts = false, cache_populated_by_fetch = true, marks_compress_block_size = 36664, primary_key_compress_block_size = 44977), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000aad4b34 4. ./build_docker/./src/DataTypes/DataTypeNullable.cpp:30: DB::DataTypeNullable::DataTypeNullable(std::shared_ptr const&) @ 0x00000000279564c1 5. std::shared_ptr std::allocate_shared[abi:v15007], std::shared_ptr&, void>(std::allocator const&, std::shared_ptr&) @ 0x000000000ab1e889 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::create(std::shared_ptr const&) @ 0x0000000027958a27 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000278ebaf7 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::getColumnsDescription(DB::ASTExpressionList const&, std::shared_ptr, DB::LoadingStrictnessLevel, bool) @ 0x0000000029197a7a 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&, DB::LoadingStrictnessLevel) const @ 0x000000002919cf0e 10. ./src/Parsers/ASTCreateQuery.h:175: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291aa55d 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000291c3415 12. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b382fc 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 15. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 19. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 20. asan_thread_start(void*) @ 0x000000000aa43059 21. ? @ 0x00007f35aab92ac3 22. ? @ 0x00007f35aac24850 2025.09.09 14:53:31.253509 [ 5360 ] {82c8dad3-e26d-422e-a985-6e7396038e4e} TCPHandler: Code: 43. DB::Exception: Nested type Tuple() cannot be inside Nullable type. (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000aad4b34 4. ./build_docker/./src/DataTypes/DataTypeNullable.cpp:30: DB::DataTypeNullable::DataTypeNullable(std::shared_ptr const&) @ 0x00000000279564c1 5. std::shared_ptr std::allocate_shared[abi:v15007], std::shared_ptr&, void>(std::allocator const&, std::shared_ptr&) @ 0x000000000ab1e889 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::create(std::shared_ptr const&) @ 0x0000000027958a27 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000278ebaf7 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::getColumnsDescription(DB::ASTExpressionList const&, std::shared_ptr, DB::LoadingStrictnessLevel, bool) @ 0x0000000029197a7a 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&, DB::LoadingStrictnessLevel) const @ 0x000000002919cf0e 10. ./src/Parsers/ASTCreateQuery.h:175: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291aa55d 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000291c3415 12. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b382fc 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 15. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 19. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 20. asan_thread_start(void*) @ 0x000000000aa43059 21. ? @ 0x00007f35aab92ac3 22. ? @ 0x00007f35aac24850 2025.09.09 14:53:31.330906 [ 4020 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 14:53:31.377991 [ 5360 ] {0f7f7122-5b97-46c3-a7b6-c778d47d4f96} executeQuery: Code: 43. DB::Exception: DataTypeLowCardinality is supported only for numbers, strings, Date or DateTime, but got Tuple(). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:55868) (comment: 02891_empty_tuple.sql) (in query: CREATE TABLE x (`i` LowCardinality(Tuple)) ENGINE = MergeTree ORDER BY tuple() SETTINGS index_granularity = 20685, min_bytes_for_wide_part = 232105235, ratio_of_defaults_for_sparse_serialization = 0.07411396503448486, replace_long_file_name_to_hash = true, max_file_name_length = 30, min_bytes_for_full_part_storage = 249270319, compact_parts_max_bytes_to_buffer = 433263342, compact_parts_max_granules_to_buffer = 20, compact_parts_merge_max_bytes_to_prefetch_part = 9622859, merge_max_block_size = 2313, old_parts_lifetime = 151., prefer_fetch_merged_part_size_threshold = 10737418240, vertical_merge_algorithm_min_rows_to_activate = 1000000, vertical_merge_algorithm_min_columns_to_activate = 100, min_merge_bytes_to_use_direct_io = 10737418240, index_granularity_bytes = 7489618, concurrent_part_removal_threshold = 0, allow_vertical_merges_from_compact_to_wide_parts = false, cache_populated_by_fetch = true, marks_compress_block_size = 36664, primary_key_compress_block_size = 44977), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000aad4b34 4. ./build_docker/./src/DataTypes/DataTypeLowCardinality.cpp:38: DB::DataTypeLowCardinality::DataTypeLowCardinality(std::shared_ptr) @ 0x00000000278fdd15 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:1460: std::shared_ptr std::allocate_shared[abi:v15007], std::shared_ptr, void>(std::allocator const&, std::shared_ptr&&) @ 0x0000000027904216 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::create(std::shared_ptr const&) @ 0x0000000027902ea7 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000278ebaf7 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::getColumnsDescription(DB::ASTExpressionList const&, std::shared_ptr, DB::LoadingStrictnessLevel, bool) @ 0x0000000029197a7a 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&, DB::LoadingStrictnessLevel) const @ 0x000000002919cf0e 10. ./src/Parsers/ASTCreateQuery.h:175: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291aa55d 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000291c3415 12. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b382fc 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 15. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 19. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 20. asan_thread_start(void*) @ 0x000000000aa43059 21. ? @ 0x00007f35aab92ac3 22. ? @ 0x00007f35aac24850 2025.09.09 14:53:31.387551 [ 5360 ] {0f7f7122-5b97-46c3-a7b6-c778d47d4f96} TCPHandler: Code: 43. DB::Exception: DataTypeLowCardinality is supported only for numbers, strings, Date or DateTime, but got Tuple(). (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000aad4b34 4. ./build_docker/./src/DataTypes/DataTypeLowCardinality.cpp:38: DB::DataTypeLowCardinality::DataTypeLowCardinality(std::shared_ptr) @ 0x00000000278fdd15 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:1460: std::shared_ptr std::allocate_shared[abi:v15007], std::shared_ptr, void>(std::allocator const&, std::shared_ptr&&) @ 0x0000000027904216 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::create(std::shared_ptr const&) @ 0x0000000027902ea7 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000278ebaf7 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::getColumnsDescription(DB::ASTExpressionList const&, std::shared_ptr, DB::LoadingStrictnessLevel, bool) @ 0x0000000029197a7a 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&, DB::LoadingStrictnessLevel) const @ 0x000000002919cf0e 10. ./src/Parsers/ASTCreateQuery.h:175: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291aa55d 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000291c3415 12. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b382fc 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 15. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 19. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 20. asan_thread_start(void*) @ 0x000000000aa43059 21. ? @ 0x00007f35aab92ac3 22. ? @ 0x00007f35aac24850 2025.09.09 14:53:31.466786 [ 2971 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:53:31.571284 [ 2975 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:53:32.121909 [ 4022 ] {68fa6ac9-179e-47be-9bfc-d7af7294ace7} executeQuery: Code: 36. DB::Exception: Cannot materialize column `x` because it doesn't have default expression. (BAD_ARGUMENTS) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:55914) (comment: 02008_materialize_column.sql) (in query: ALTER TABLE tmp MATERIALIZE 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Interpreters/MutationsInterpreter.cpp:782: DB::MutationsInterpreter::prepare(bool) @ 0x00000000295a6a45 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::MutationsInterpreter::MutationsInterpreter(DB::MutationsInterpreter::Source, std::shared_ptr, DB::MutationCommands, std::vector>, std::shared_ptr, DB::MutationsInterpreter::Settings) @ 0x0000000029599786 6. ./build_docker/./src/Interpreters/MutationsInterpreter.cpp:377: DB::MutationsInterpreter::MutationsInterpreter(std::shared_ptr, std::shared_ptr, DB::MutationCommands, std::shared_ptr, DB::MutationsInterpreter::Settings) @ 0x0000000029597e75 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:228: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000029174908 8. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x0000000029170711 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b382fc 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 14:53:32.131752 [ 4022 ] {68fa6ac9-179e-47be-9bfc-d7af7294ace7} TCPHandler: Code: 36. DB::Exception: Cannot materialize column `x` because it doesn't have default expression. (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Interpreters/MutationsInterpreter.cpp:782: DB::MutationsInterpreter::prepare(bool) @ 0x00000000295a6a45 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::MutationsInterpreter::MutationsInterpreter(DB::MutationsInterpreter::Source, std::shared_ptr, DB::MutationCommands, std::vector>, std::shared_ptr, DB::MutationsInterpreter::Settings) @ 0x0000000029599786 6. ./build_docker/./src/Interpreters/MutationsInterpreter.cpp:377: DB::MutationsInterpreter::MutationsInterpreter(std::shared_ptr, std::shared_ptr, DB::MutationCommands, std::shared_ptr, DB::MutationsInterpreter::Settings) @ 0x0000000029597e75 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:228: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000029174908 8. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x0000000029170711 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b382fc 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 14:53:32.150580 [ 4023 ] {5c354dca-56d9-446a-af8f-07e27dd160c0} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=0, jobs=0). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:55956) (comment: 01925_map_populate_series_on_map.sql) (in query: select mapPopulateSeries(m) from map_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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af80b71 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80746 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d34b5ca 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000002d3486e4 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000002d34827b 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002d36bcf7 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 12. asan_thread_start(void*) @ 0x000000000aa43059 13. ? @ 0x00007f35aab92ac3 14. ? @ 0x00007f35aac24850 2025.09.09 14:53:32.161025 [ 4023 ] {5c354dca-56d9-446a-af8f-07e27dd160c0} 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af80b71 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80746 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d34b5ca 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000002d3486e4 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000002d34827b 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002d36bcf7 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 12. asan_thread_start(void*) @ 0x000000000aa43059 13. ? @ 0x00007f35aab92ac3 14. ? @ 0x00007f35aac24850 2025.09.09 14:53:32.354528 [ 4023 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 14:53:32.421815 [ 5360 ] {85bab2f5-3e46-4fb2-9037-1f0731a43786} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=13, jobs=0): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:55868) (comment: 02891_empty_tuple.sql) (in query: select * from x order by () settings max_threads = 1;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af80b71 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80746 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002c765aab 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:1197: ? @ 0x000000002c7602b8 8. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x000000002c75fc2b 9. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:0: DB::MergeTreeReaderCompact::MergeTreeReaderCompact(std::shared_ptr, DB::NamesAndTypesList, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*, DB::MarkCache*, DB::MarkRanges, DB::MergeTreeReaderSettings, std::map, std::allocator>>, std::function const&, int) @ 0x000000002c7aee03 10. ./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.h:16: DB::MergeTreeReaderCompactSingleBuffer::MergeTreeReaderCompactSingleBuffer&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int&&) @ 0x000000002c5d6d21 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::MergeTreeDataPartCompact::getReader(DB::NamesAndTypesList const&, std::shared_ptr const&, DB::MarkRanges const&, std::unordered_map, std::equal_to, std::allocator>> const&, DB::UncompressedCache*, DB::MarkCache*, std::shared_ptr const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) const @ 0x000000002c5d1037 12. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:44: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x000000002c82a56b 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:295: DB::MergeTreeReadPoolBase::createTask(std::shared_ptr, DB::MarkRanges, DB::MergeTreeReadTask*) const @ 0x000000002de9c234 14. ./build_docker/./src/Storages/MergeTree/MergeTreeReadPoolInOrder.cpp:72: DB::MergeTreeReadPoolInOrder::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x000000002deff671 15. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectAlgorithms.cpp:17: DB::MergeTreeInOrderSelectAlgorithm::getNewTask(DB::IMergeTreeReadPool&, DB::MergeTreeReadTask*) @ 0x000000002dea3919 16. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:0: DB::MergeTreeSelectProcessor::read() @ 0x000000002c8241d2 17. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000002de6d77a 18. ./build_docker/./src/Processors/ISource.cpp:0: DB::ISource::work() @ 0x000000002d3290a1 19. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 20. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 21. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000002d34877c 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000002d34827b 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*) @ 0x000000002d36bcf7 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 26. asan_thread_start(void*) @ 0x000000000aa43059 27. ? @ 0x00007f35aab92ac3 28. ? @ 0x00007f35aac24850 2025.09.09 14:53:32.424549 [ 5360 ] {85bab2f5-3e46-4fb2-9037-1f0731a43786} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=13, jobs=0): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af80b71 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80746 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002c765aab 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:1197: ? @ 0x000000002c7602b8 8. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x000000002c75fc2b 9. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:0: DB::MergeTreeReaderCompact::MergeTreeReaderCompact(std::shared_ptr, DB::NamesAndTypesList, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*, DB::MarkCache*, DB::MarkRanges, DB::MergeTreeReaderSettings, std::map, std::allocator>>, std::function const&, int) @ 0x000000002c7aee03 10. ./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.h:16: DB::MergeTreeReaderCompactSingleBuffer::MergeTreeReaderCompactSingleBuffer&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int&&) @ 0x000000002c5d6d21 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::MergeTreeDataPartCompact::getReader(DB::NamesAndTypesList const&, std::shared_ptr const&, DB::MarkRanges const&, std::unordered_map, std::equal_to, std::allocator>> const&, DB::UncompressedCache*, DB::MarkCache*, std::shared_ptr const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) const @ 0x000000002c5d1037 12. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:44: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x000000002c82a56b 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:295: DB::MergeTreeReadPoolBase::createTask(std::shared_ptr, DB::MarkRanges, DB::MergeTreeReadTask*) const @ 0x000000002de9c234 14. ./build_docker/./src/Storages/MergeTree/MergeTreeReadPoolInOrder.cpp:72: DB::MergeTreeReadPoolInOrder::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x000000002deff671 15. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectAlgorithms.cpp:17: DB::MergeTreeInOrderSelectAlgorithm::getNewTask(DB::IMergeTreeReadPool&, DB::MergeTreeReadTask*) @ 0x000000002dea3919 16. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:0: DB::MergeTreeSelectProcessor::read() @ 0x000000002c8241d2 17. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000002de6d77a 18. ./build_docker/./src/Processors/ISource.cpp:0: DB::ISource::work() @ 0x000000002d3290a1 19. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 20. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 21. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000002d34877c 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000002d34827b 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*) @ 0x000000002d36bcf7 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 26. asan_thread_start(void*) @ 0x000000000aa43059 27. ? @ 0x00007f35aab92ac3 28. ? @ 0x00007f35aac24850 2025.09.09 14:53:32.468951 [ 2993 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:53:32.576359 [ 2995 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:53:32.678168 [ 2686 ] {27f774e5-b588-49bb-b1b0-0d81403c2e73} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:43238) (comment: 02891_empty_tuple.sql) (in query: DROP DATABASE IF EXISTS test_ryps6uk2 ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aac868e 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x00000000286b57c7 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x00000000291f5630 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:361: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000291edc97 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x00000000291ebf11 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x00000000291eb7ed 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b382fc 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1529: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000029b3ed3f 11. ./build_docker/./src/Server/HTTPHandler.cpp:529: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000002d0662d1 12. ./build_docker/./src/Server/HTTPHandler.cpp:705: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000002d06d139 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000002d1cc337 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 18. asan_thread_start(void*) @ 0x000000000aa43059 19. ? @ 0x00007f35aab92ac3 20. ? @ 0x00007f35aac24850 2025.09.09 14:53:32.681256 [ 2686 ] {27f774e5-b588-49bb-b1b0-0d81403c2e73} DynamicQueryHandler: Code: 219. DB::Exception: New table 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aac868e 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x00000000286b57c7 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x00000000291f5630 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:361: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000291edc97 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x00000000291ebf11 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x00000000291eb7ed 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b382fc 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1529: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000029b3ed3f 11. ./build_docker/./src/Server/HTTPHandler.cpp:529: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000002d0662d1 12. ./build_docker/./src/Server/HTTPHandler.cpp:705: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000002d06d139 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000002d1cc337 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 18. asan_thread_start(void*) @ 0x000000000aa43059 19. ? @ 0x00007f35aab92ac3 20. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:53:33.470916 [ 3020 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:53:33.539634 [ 3604 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 14:53:33.578710 [ 3014 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:53:34.166856 [ 4020 ] {4fff2e05-9c3b-4813-a2b8-9fa2e11fe923} executeQuery: Code: 127. DB::Exception: Duplicated index name idx_a is not allowed. Please use different index names. (ILLEGAL_INDEX) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:56004) (comment: 02884_duplicate_index_name.sql) (in query: CREATE TABLE test_dup_index (`a` Int64, `b` Int64, INDEX idx_a a TYPE minmax GRANULARITY 1, INDEX idx_a b TYPE minmax GRANULARITY 1) ENGINE = MergeTree ORDER BY a SETTINGS index_granularity = 34290, min_bytes_for_wide_part = 563541971, ratio_of_defaults_for_sparse_serialization = 0., replace_long_file_name_to_hash = true, max_file_name_length = 0, min_bytes_for_full_part_storage = 282405901, compact_parts_max_bytes_to_buffer = 338333911, compact_parts_max_granules_to_buffer = 196, compact_parts_merge_max_bytes_to_prefetch_part = 196920, merge_max_block_size = 13372, old_parts_lifetime = 133., 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 = 4455551944, index_granularity_bytes = 22689260, concurrent_part_removal_threshold = 44, allow_vertical_merges_from_compact_to_wide_parts = false, cache_populated_by_fetch = false, marks_compress_block_size = 76347, primary_key_compress_block_size = 36837), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000aad4b34 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:780: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&, DB::LoadingStrictnessLevel) const @ 0x00000000291a15ca 5. ./src/Parsers/ASTCreateQuery.h:175: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291aa55d 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000291c3415 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b382fc 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 15. asan_thread_start(void*) @ 0x000000000aa43059 16. ? @ 0x00007f35aab92ac3 17. ? @ 0x00007f35aac24850 2025.09.09 14:53:34.181160 [ 4020 ] {4fff2e05-9c3b-4813-a2b8-9fa2e11fe923} TCPHandler: Code: 127. DB::Exception: Duplicated index name idx_a is not allowed. Please use different index names. (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000aad4b34 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:780: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&, DB::LoadingStrictnessLevel) const @ 0x00000000291a15ca 5. ./src/Parsers/ASTCreateQuery.h:175: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291aa55d 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000291c3415 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b382fc 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 15. asan_thread_start(void*) @ 0x000000000aa43059 16. ? @ 0x00007f35aab92ac3 17. ? @ 0x00007f35aac24850 2025.09.09 14:53:34.472906 [ 3047 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:53:34.562293 [ 4020 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 14:53:34.580781 [ 3049 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:53:35.559953 [ 3070 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:53:35.582794 [ 3069 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:53:35.610324 [ 3766 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 14:53:36.562311 [ 3097 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:53:36.589695 [ 3099 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:53:36.639391 [ 3604 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 14:53:37.564520 [ 3122 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:53:37.592119 [ 3123 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:53:37.665690 [ 3604 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 14:53:37.888840 [ 4022 ] {d6928668-4ea6-47ba-ab41-d03bbc58e8bb} executeQuery: Code: 128. DB::Exception: Too large array size in GenerateRandom: 9223372036854775807, maximum: 1073741824. (TOO_LARGE_ARRAY_SIZE) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:56132) (comment: 01352_generate_random_overflow.sql) (in query: SELECT i FROM generateRandom('i Array(Nullable(Enum8(\'hello\' = 1, \'world\' = 5)))', 1025, 65535, 9223372036854775807) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, unsigned long const&) @ 0x000000000cf79c9a 4. ./build_docker/./src/Storages/StorageGenerateRandom.cpp:624: DB::StorageGenerateRandom::StorageGenerateRandom(DB::StorageID const&, DB::ColumnsDescription const&, String const&, unsigned long, unsigned long, std::optional const&) @ 0x000000002b7f4d10 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:1460: std::shared_ptr std::allocate_shared[abi:v15007], DB::StorageID, DB::ColumnsDescription&, String, unsigned long const&, unsigned long const&, std::optional const&, void>(std::allocator const&, DB::StorageID&&, DB::ColumnsDescription&, String&&, unsigned long const&, unsigned long const&, std::optional const&) @ 0x00000000260038bb 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:962: DB::(anonymous namespace)::TableFunctionGenerateRandom::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x0000000026003090 7. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x00000000265c241e 8. ./build_docker/./src/Interpreters/Context.cpp:2234: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000285361d2 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4819: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000002837024e 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000283ba404 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002835ad09 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000028359104 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000028357f0d 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002921bdcc 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&) @ 0x000000002941f313 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&) @ 0x0000000029419aef 17. ./contrib/llvm-project/libcxx/include/vector:432: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000029421f5d 18. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000029344c1b 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*) @ 0x0000000029b3703b 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 21. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 22. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 26. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 27. asan_thread_start(void*) @ 0x000000000aa43059 28. ? @ 0x00007f35aab92ac3 29. ? @ 0x00007f35aac24850 2025.09.09 14:53:37.906628 [ 4022 ] {d6928668-4ea6-47ba-ab41-d03bbc58e8bb} TCPHandler: Code: 128. DB::Exception: Too large array size in GenerateRandom: 9223372036854775807, maximum: 1073741824. (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, unsigned long const&) @ 0x000000000cf79c9a 4. ./build_docker/./src/Storages/StorageGenerateRandom.cpp:624: DB::StorageGenerateRandom::StorageGenerateRandom(DB::StorageID const&, DB::ColumnsDescription const&, String const&, unsigned long, unsigned long, std::optional const&) @ 0x000000002b7f4d10 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:1460: std::shared_ptr std::allocate_shared[abi:v15007], DB::StorageID, DB::ColumnsDescription&, String, unsigned long const&, unsigned long const&, std::optional const&, void>(std::allocator const&, DB::StorageID&&, DB::ColumnsDescription&, String&&, unsigned long const&, unsigned long const&, std::optional const&) @ 0x00000000260038bb 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:962: DB::(anonymous namespace)::TableFunctionGenerateRandom::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x0000000026003090 7. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x00000000265c241e 8. ./build_docker/./src/Interpreters/Context.cpp:2234: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000285361d2 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4819: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000002837024e 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000283ba404 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002835ad09 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000028359104 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000028357f0d 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002921bdcc 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&) @ 0x000000002941f313 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&) @ 0x0000000029419aef 17. ./contrib/llvm-project/libcxx/include/vector:432: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000029421f5d 18. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000029344c1b 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*) @ 0x0000000029b3703b 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 21. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 22. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 26. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 27. asan_thread_start(void*) @ 0x000000000aa43059 28. ? @ 0x00007f35aab92ac3 29. ? @ 0x00007f35aac24850 2025.09.09 14:53:38.566943 [ 3139 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:53:38.594419 [ 3128 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:53:38.697852 [ 3766 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 14:53:39.569164 [ 3157 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:53:39.596599 [ 3159 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:53:39.719968 [ 3640 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 14:53:39.968894 [ 4022 ] {477450f2-9a23-4f6a-88cb-279f7f9f687e} executeQuery: Code: 69. DB::Exception: Cannot convert value '-3': it cannot be represented as UInt128. (ARGUMENT_OUT_OF_BOUND) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:58136) (comment: 02560_with_fill_int256_int.sql) (in query: SELECT (number * 2)::UInt128 FROM numbers(10) ORDER BY 1 ASC WITH FILL FROM -3 TO 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000ac6ad20 4. ./build_docker/./src/Interpreters/convertFieldToType.cpp:623: DB::convertFieldToTypeOrThrow(DB::Field const&, DB::IDataType const&, DB::IDataType const*) @ 0x0000000029aa90ac 5. ./build_docker/./src/Processors/Transforms/FillingTransform.cpp:0: DB::FillingTransform::FillingTransform(DB::Block const&, DB::SortDescription const&, DB::SortDescription const&, std::shared_ptr, bool) @ 0x000000002dd9580d 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000002dd91fac 7. ./build_docker/./src/QueryPipeline/Pipe.cpp:591: DB::Pipe::addSimpleTransform(std::function (DB::Block const&, DB::Pipe::StreamType)> const&)::$_0::operator()(DB::OutputPort*&, DB::Pipe::StreamType) const @ 0x000000002780b1b7 8. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::Pipe::addSimpleTransform(std::function (DB::Block const&, DB::Pipe::StreamType)> const&) @ 0x000000002780abfd 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002dd90c15 10. ./build_docker/./src/Processors/QueryPlan/ITransformingStep.cpp:0: DB::ITransformingStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000002ddba428 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000002ddff11e 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000002942117f 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x00000000294209e7 14. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b382fc 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 17. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 21. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 22. asan_thread_start(void*) @ 0x000000000aa43059 23. ? @ 0x00007f35aab92ac3 24. ? @ 0x00007f35aac24850 2025.09.09 14:53:39.971421 [ 4022 ] {477450f2-9a23-4f6a-88cb-279f7f9f687e} TCPHandler: Code: 69. DB::Exception: Cannot convert value '-3': it cannot be represented as UInt128. (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000ac6ad20 4. ./build_docker/./src/Interpreters/convertFieldToType.cpp:623: DB::convertFieldToTypeOrThrow(DB::Field const&, DB::IDataType const&, DB::IDataType const*) @ 0x0000000029aa90ac 5. ./build_docker/./src/Processors/Transforms/FillingTransform.cpp:0: DB::FillingTransform::FillingTransform(DB::Block const&, DB::SortDescription const&, DB::SortDescription const&, std::shared_ptr, bool) @ 0x000000002dd9580d 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000002dd91fac 7. ./build_docker/./src/QueryPipeline/Pipe.cpp:591: DB::Pipe::addSimpleTransform(std::function (DB::Block const&, DB::Pipe::StreamType)> const&)::$_0::operator()(DB::OutputPort*&, DB::Pipe::StreamType) const @ 0x000000002780b1b7 8. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::Pipe::addSimpleTransform(std::function (DB::Block const&, DB::Pipe::StreamType)> const&) @ 0x000000002780abfd 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002dd90c15 10. ./build_docker/./src/Processors/QueryPlan/ITransformingStep.cpp:0: DB::ITransformingStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000002ddba428 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000002ddff11e 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000002942117f 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x00000000294209e7 14. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b382fc 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 17. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 21. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 22. asan_thread_start(void*) @ 0x000000000aa43059 23. ? @ 0x00007f35aab92ac3 24. ? @ 0x00007f35aac24850 2025.09.09 14:53:40.026560 [ 4022 ] {1139181c-67d3-4c3c-84ed-a1958da1eefd} executeQuery: Code: 69. DB::Exception: Cannot convert value '-3': it cannot be represented as UInt256. (ARGUMENT_OUT_OF_BOUND) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:58136) (comment: 02560_with_fill_int256_int.sql) (in query: SELECT (number * 2)::UInt256 FROM numbers(10) ORDER BY 1 ASC WITH FILL FROM -3 TO 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000ac6ad20 4. ./build_docker/./src/Interpreters/convertFieldToType.cpp:623: DB::convertFieldToTypeOrThrow(DB::Field const&, DB::IDataType const&, DB::IDataType const*) @ 0x0000000029aa90ac 5. ./build_docker/./src/Processors/Transforms/FillingTransform.cpp:0: DB::FillingTransform::FillingTransform(DB::Block const&, DB::SortDescription const&, DB::SortDescription const&, std::shared_ptr, bool) @ 0x000000002dd9580d 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000002dd91fac 7. ./build_docker/./src/QueryPipeline/Pipe.cpp:591: DB::Pipe::addSimpleTransform(std::function (DB::Block const&, DB::Pipe::StreamType)> const&)::$_0::operator()(DB::OutputPort*&, DB::Pipe::StreamType) const @ 0x000000002780b1b7 8. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::Pipe::addSimpleTransform(std::function (DB::Block const&, DB::Pipe::StreamType)> const&) @ 0x000000002780abfd 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002dd90c15 10. ./build_docker/./src/Processors/QueryPlan/ITransformingStep.cpp:0: DB::ITransformingStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000002ddba428 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000002ddff11e 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000002942117f 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x00000000294209e7 14. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b382fc 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 17. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 21. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 22. asan_thread_start(void*) @ 0x000000000aa43059 23. ? @ 0x00007f35aab92ac3 24. ? @ 0x00007f35aac24850 2025.09.09 14:53:40.029889 [ 4022 ] {1139181c-67d3-4c3c-84ed-a1958da1eefd} TCPHandler: Code: 69. DB::Exception: Cannot convert value '-3': it cannot be represented as UInt256. (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000ac6ad20 4. ./build_docker/./src/Interpreters/convertFieldToType.cpp:623: DB::convertFieldToTypeOrThrow(DB::Field const&, DB::IDataType const&, DB::IDataType const*) @ 0x0000000029aa90ac 5. ./build_docker/./src/Processors/Transforms/FillingTransform.cpp:0: DB::FillingTransform::FillingTransform(DB::Block const&, DB::SortDescription const&, DB::SortDescription const&, std::shared_ptr, bool) @ 0x000000002dd9580d 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000002dd91fac 7. ./build_docker/./src/QueryPipeline/Pipe.cpp:591: DB::Pipe::addSimpleTransform(std::function (DB::Block const&, DB::Pipe::StreamType)> const&)::$_0::operator()(DB::OutputPort*&, DB::Pipe::StreamType) const @ 0x000000002780b1b7 8. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::Pipe::addSimpleTransform(std::function (DB::Block const&, DB::Pipe::StreamType)> const&) @ 0x000000002780abfd 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002dd90c15 10. ./build_docker/./src/Processors/QueryPlan/ITransformingStep.cpp:0: DB::ITransformingStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000002ddba428 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000002ddff11e 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000002942117f 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x00000000294209e7 14. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b382fc 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 17. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 21. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 22. asan_thread_start(void*) @ 0x000000000aa43059 23. ? @ 0x00007f35aab92ac3 24. ? @ 0x00007f35aac24850 2025.09.09 14:53:40.573328 [ 3189 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:53:40.598784 [ 3192 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:53:40.759938 [ 3640 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 14:53:41.575324 [ 3221 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:53:41.601476 [ 3223 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:53:41.886510 [ 3722 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 14:53:42.577761 [ 2757 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:53:42.605933 [ 2756 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:53:42.974446 [ 3722 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 14:53:43.580010 [ 2780 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:53:43.609447 [ 2784 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:53:43.979733 [ 4016 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 14:53:44.593471 [ 2824 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:53:44.611423 [ 2822 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:53:44.893666 [ 2686 ] {78028201-17db-4e9a-9c9f-c97341ef3d2f} executeQuery: Code: 47. DB::Exception: Missing columns: 'nonexistent' while processing query: 'isZeroOrNull(nonexistent = 0), _block_number, _partition_value, _part_data_version, _part_index, s, _partition_id, x, _part, m, _part_offset, _sample_factor, _block_offset, _part_uuid, d', required columns: 'nonexistent' '_partition_id' '_block_number' '_partition_value' '_part_data_version' '_part_index' 's' '_part' 'x' 'm' '_part_offset' '_sample_factor' '_part_uuid' '_block_offset' 'd', maybe you meant: 's', 'x', 'm' or 'd'. (UNKNOWN_IDENTIFIER) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:58274) (comment: 00652_replicated_mutations_zookeeper.sh) (in query: ALTER TABLE mutations_r1 DELETE WHERE nonexistent = 0), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./build_docker/./src/Interpreters/TreeRewriter.cpp:1280: DB::TreeRewriterResult::collectUsedColumns(std::shared_ptr const&, bool, bool) @ 0x000000002999fb7c 4. ./build_docker/./src/Interpreters/TreeRewriter.cpp:1537: DB::TreeRewriter::analyze(std::shared_ptr&, DB::NamesAndTypesList const&, std::shared_ptr, std::shared_ptr const&, bool, bool, bool, bool) const @ 0x00000000299b2bea 5. ./build_docker/./src/Interpreters/MutationsInterpreter.cpp:1115: DB::MutationsInterpreter::prepareMutationStages(std::vector>&, bool) @ 0x00000000295ac042 6. ./build_docker/./src/Interpreters/MutationsInterpreter.cpp:0: DB::MutationsInterpreter::prepare(bool) @ 0x00000000295a5782 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::MutationsInterpreter::MutationsInterpreter(DB::MutationsInterpreter::Source, std::shared_ptr, DB::MutationCommands, std::vector>, std::shared_ptr, DB::MutationsInterpreter::Settings) @ 0x0000000029599786 8. ./build_docker/./src/Interpreters/MutationsInterpreter.cpp:377: DB::MutationsInterpreter::MutationsInterpreter(std::shared_ptr, std::shared_ptr, DB::MutationCommands, std::shared_ptr, DB::MutationsInterpreter::Settings) @ 0x0000000029597e75 9. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:228: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000029174908 10. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x0000000029170711 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b382fc 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 14. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 19. asan_thread_start(void*) @ 0x000000000aa43059 20. ? @ 0x00007f35aab92ac3 21. ? @ 0x00007f35aac24850 2025.09.09 14:53:44.916717 [ 2686 ] {78028201-17db-4e9a-9c9f-c97341ef3d2f} TCPHandler: Code: 47. DB::Exception: Missing columns: 'nonexistent' while processing query: 'isZeroOrNull(nonexistent = 0), _block_number, _partition_value, _part_data_version, _part_index, s, _partition_id, x, _part, m, _part_offset, _sample_factor, _block_offset, _part_uuid, d', required columns: 'nonexistent' '_partition_id' '_block_number' '_partition_value' '_part_data_version' '_part_index' 's' '_part' 'x' 'm' '_part_offset' '_sample_factor' '_part_uuid' '_block_offset' 'd', maybe you meant: 's', 'x', 'm' or 'd'. (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./build_docker/./src/Interpreters/TreeRewriter.cpp:1280: DB::TreeRewriterResult::collectUsedColumns(std::shared_ptr const&, bool, bool) @ 0x000000002999fb7c 4. ./build_docker/./src/Interpreters/TreeRewriter.cpp:1537: DB::TreeRewriter::analyze(std::shared_ptr&, DB::NamesAndTypesList const&, std::shared_ptr, std::shared_ptr const&, bool, bool, bool, bool) const @ 0x00000000299b2bea 5. ./build_docker/./src/Interpreters/MutationsInterpreter.cpp:1115: DB::MutationsInterpreter::prepareMutationStages(std::vector>&, bool) @ 0x00000000295ac042 6. ./build_docker/./src/Interpreters/MutationsInterpreter.cpp:0: DB::MutationsInterpreter::prepare(bool) @ 0x00000000295a5782 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::MutationsInterpreter::MutationsInterpreter(DB::MutationsInterpreter::Source, std::shared_ptr, DB::MutationCommands, std::vector>, std::shared_ptr, DB::MutationsInterpreter::Settings) @ 0x0000000029599786 8. ./build_docker/./src/Interpreters/MutationsInterpreter.cpp:377: DB::MutationsInterpreter::MutationsInterpreter(std::shared_ptr, std::shared_ptr, DB::MutationCommands, std::shared_ptr, DB::MutationsInterpreter::Settings) @ 0x0000000029597e75 9. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:228: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000029174908 10. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x0000000029170711 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b382fc 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 14. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 19. asan_thread_start(void*) @ 0x000000000aa43059 20. ? @ 0x00007f35aab92ac3 21. ? @ 0x00007f35aac24850 2025.09.09 14:53:45.028993 [ 3640 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 14:53:45.582841 [ 4025 ] {7213d63b-34c5-4b66-b10b-0b7bf5ae6ae7} executeQuery: Code: 38. DB::Exception: Cannot parse date: value is too short: while converting '11' to Date. (CANNOT_PARSE_DATE) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:58306) (comment: 00652_replicated_mutations_zookeeper.sh) (in query: ALTER TABLE mutations_r1 DELETE WHERE d = '11'), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aac868e 4. ./build_docker/./src/IO/ReadHelpers.cpp:1363: void DB::readDateTextFallback(LocalDate&, DB::ReadBuffer&, char const*) @ 0x000000001aee2747 5. ./src/Common/LocalDate.h:117: DB::SerializationDate::deserializeTextEscaped(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x0000000027acc213 6. ./src/IO/BufferBase.h:41: DB::SerializationDate::deserializeWholeText(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x0000000027acbfae 7. ./build_docker/./src/Interpreters/convertFieldToType.cpp:554: DB::(anonymous namespace)::convertFieldToTypeImpl(DB::Field const&, DB::IDataType const&, DB::IDataType const*) @ 0x0000000029aa606f 8. ./build_docker/./src/Interpreters/convertFieldToType.cpp:611: DB::convertFieldToType(DB::Field const&, DB::IDataType const&, DB::IDataType const*) @ 0x0000000029aa2141 9. DB::FunctionComparison::executeWithConstString(std::shared_ptr const&, DB::IColumn const*, DB::IColumn const*, std::shared_ptr const&, std::shared_ptr const&, unsigned long) const @ 0x000000000f345710 10. DB::FunctionComparison::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000f3133d1 11. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aa8c635 12. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aac91d5 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000cccccfb 14. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccce65c 15. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd2030 16. ./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) @ 0x0000000028259428 17. ./contrib/llvm-project/libcxx/include/vector:961: DB::ActionsDAG::updateHeader(DB::Block const&) const @ 0x0000000028256e17 18. ./build_docker/./src/Processors/Transforms/FilterTransform.cpp:0: DB::FilterTransform::transformHeader(DB::Block const&, DB::ActionsDAG const*, String const&, bool) @ 0x000000002d9c9921 19. ./build_docker/./src/Processors/QueryPlan/FilterStep.cpp:0: DB::FilterStep::FilterStep(DB::DataStream const&, DB::ActionsDAG, String, bool) @ 0x000000002ddb09e1 20. ./contrib/llvm-project/libcxx/include/string:1499: std::__unique_if::__unique_single std::make_unique[abi:v15007](DB::DataStream const&, DB::ActionsDAG&&, String const&, bool&&) @ 0x00000000295bc747 21. ./build_docker/./src/Interpreters/MutationsInterpreter.cpp:0: DB::MutationsInterpreter::addStreamsForLaterStages(std::vector> const&, DB::QueryPlan&) const @ 0x00000000295ae99b 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000295b3dc7 23. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:228: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000029174914 24. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x0000000029170711 25. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b382fc 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 27. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 28. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 2025.09.09 14:53:45.595543 [ 2855 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:53:45.595924 [ 4025 ] {7213d63b-34c5-4b66-b10b-0b7bf5ae6ae7} TCPHandler: Code: 38. DB::Exception: Cannot parse date: value is too short: while converting '11' to Date. (CANNOT_PARSE_DATE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aac868e 4. ./build_docker/./src/IO/ReadHelpers.cpp:1363: void DB::readDateTextFallback(LocalDate&, DB::ReadBuffer&, char const*) @ 0x000000001aee2747 5. ./src/Common/LocalDate.h:117: DB::SerializationDate::deserializeTextEscaped(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x0000000027acc213 6. ./src/IO/BufferBase.h:41: DB::SerializationDate::deserializeWholeText(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x0000000027acbfae 7. ./build_docker/./src/Interpreters/convertFieldToType.cpp:554: DB::(anonymous namespace)::convertFieldToTypeImpl(DB::Field const&, DB::IDataType const&, DB::IDataType const*) @ 0x0000000029aa606f 8. ./build_docker/./src/Interpreters/convertFieldToType.cpp:611: DB::convertFieldToType(DB::Field const&, DB::IDataType const&, DB::IDataType const*) @ 0x0000000029aa2141 9. DB::FunctionComparison::executeWithConstString(std::shared_ptr const&, DB::IColumn const*, DB::IColumn const*, std::shared_ptr const&, std::shared_ptr const&, unsigned long) const @ 0x000000000f345710 10. DB::FunctionComparison::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000f3133d1 11. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aa8c635 12. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aac91d5 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000cccccfb 14. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccce65c 15. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd2030 16. ./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) @ 0x0000000028259428 17. ./contrib/llvm-project/libcxx/include/vector:961: DB::ActionsDAG::updateHeader(DB::Block const&) const @ 0x0000000028256e17 18. ./build_docker/./src/Processors/Transforms/FilterTransform.cpp:0: DB::FilterTransform::transformHeader(DB::Block const&, DB::ActionsDAG const*, String const&, bool) @ 0x000000002d9c9921 19. ./build_docker/./src/Processors/QueryPlan/FilterStep.cpp:0: DB::FilterStep::FilterStep(DB::DataStream const&, DB::ActionsDAG, String, bool) @ 0x000000002ddb09e1 20. ./contrib/llvm-project/libcxx/include/string:1499: std::__unique_if::__unique_single std::make_unique[abi:v15007](DB::DataStream const&, DB::ActionsDAG&&, String const&, bool&&) @ 0x00000000295bc747 21. ./build_docker/./src/Interpreters/MutationsInterpreter.cpp:0: DB::MutationsInterpreter::addStreamsForLaterStages(std::vector> const&, DB::QueryPlan&) const @ 0x00000000295ae99b 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000295b3dc7 23. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:228: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000029174914 24. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x0000000029170711 25. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b382fc 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 27. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 28. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 2025.09.09 14:53:45.613520 [ 2856 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:53:46.135584 [ 4025 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 14:53:46.593967 [ 3326 ] {} 5c9d53ed-2b19-494d-b534-5ce8bffac442::20000101_20000101_1_1_0_2 (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af80b71 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80746 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d34b5ca 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000002d3486e4 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000002d34827b 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002d36bcf7 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 12. asan_thread_start(void*) @ 0x000000000aa43059 13. ? @ 0x00007f35aab92ac3 14. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:53:46.597418 [ 2911 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:53:46.601545 [ 3326 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {5c9d53ed-2b19-494d-b534-5ce8bffac442::20000101_20000101_1_1_0_2}: 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af80b71 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80746 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d34b5ca 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000002d3486e4 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000002d34827b 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002d36bcf7 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 12. asan_thread_start(void*) @ 0x000000000aa43059 13. ? @ 0x00007f35aab92ac3 14. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:53:46.624112 [ 2915 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:53:46.645549 [ 3340 ] {} 5c9d53ed-2b19-494d-b534-5ce8bffac442::20000101_20000101_0_0_0_2 (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af80b71 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80746 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d34b5ca 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000002d3486e4 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000002d34827b 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002d36bcf7 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 12. asan_thread_start(void*) @ 0x000000000aa43059 13. ? @ 0x00007f35aab92ac3 14. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:53:46.713826 [ 3340 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {5c9d53ed-2b19-494d-b534-5ce8bffac442::20000101_20000101_0_0_0_2}: 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af80b71 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80746 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d34b5ca 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000002d3486e4 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000002d34827b 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002d36bcf7 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 12. asan_thread_start(void*) @ 0x000000000aa43059 13. ? @ 0x00007f35aab92ac3 14. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:53:47.199423 [ 2688 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 14:53:47.599064 [ 2951 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:53:47.696463 [ 3766 ] {88431ac3-2ab6-45f6-b95e-ebc285120e50} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=3, jobs=1). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:58356) (comment: 02293_selected_rows_and_merges.sh) (in query: select ProfileEvents['SelectedRows'], ProfileEvents['SelectedBytes'], ProfileEvents['MergedRows'], ProfileEvents['MergedUncompressedBytes'] from system.query_log where query_id = '8e06f521a120837c45d070e737e145ad' and type = 'QueryFinish' and query like 'optimize%' 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af80b71 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af82f33 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002c64fc80 7. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1723: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr, unsigned long, std::shared_ptr, std::equal_to, std::allocator>>>, DB::MergeTreeData const&, std::vector> const&, std::shared_ptr, std::optional&, bool) @ 0x000000002de379fd 8. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1437: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000002de3554f 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:0: DB::ReadFromMergeTree::getAnalysisResult() const @ 0x000000002de41345 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:2022: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000002de4404c 11. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000002ddb933c 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000002ddff11e 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000002942117f 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x00000000294209e7 15. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b382fc 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 18. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 22. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 14:53:47.713856 [ 2953 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:53:47.726400 [ 3766 ] {88431ac3-2ab6-45f6-b95e-ebc285120e50} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=3, jobs=1). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af80b71 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af82f33 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002c64fc80 7. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1723: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr, unsigned long, std::shared_ptr, std::equal_to, std::allocator>>>, DB::MergeTreeData const&, std::vector> const&, std::shared_ptr, std::optional&, bool) @ 0x000000002de379fd 8. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1437: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000002de3554f 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:0: DB::ReadFromMergeTree::getAnalysisResult() const @ 0x000000002de41345 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:2022: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000002de4404c 11. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000002ddb933c 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000002ddff11e 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000002942117f 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x00000000294209e7 15. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b382fc 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 18. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 22. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 14:53:47.954225 [ 4017 ] {6e78cc09-949c-4843-8f78-c8e8997e349d} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:35032) (comment: 02293_selected_rows_and_merges.sh) (in query: DROP DATABASE IF EXISTS test_wglpg8q9 ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aac868e 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x00000000286b57c7 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x00000000291f5630 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:361: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000291edc97 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x00000000291ebf11 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x00000000291eb7ed 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b382fc 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1529: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000029b3ed3f 11. ./build_docker/./src/Server/HTTPHandler.cpp:529: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000002d0662d1 12. ./build_docker/./src/Server/HTTPHandler.cpp:705: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000002d06d139 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000002d1cc337 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 18. asan_thread_start(void*) @ 0x000000000aa43059 19. ? @ 0x00007f35aab92ac3 20. ? @ 0x00007f35aac24850 2025.09.09 14:53:47.958395 [ 4017 ] {6e78cc09-949c-4843-8f78-c8e8997e349d} DynamicQueryHandler: Code: 219. DB::Exception: New table 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aac868e 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x00000000286b57c7 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x00000000291f5630 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:361: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000291edc97 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x00000000291ebf11 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x00000000291eb7ed 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b382fc 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1529: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000029b3ed3f 11. ./build_docker/./src/Server/HTTPHandler.cpp:529: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000002d0662d1 12. ./build_docker/./src/Server/HTTPHandler.cpp:705: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000002d06d139 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000002d1cc337 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 18. asan_thread_start(void*) @ 0x000000000aa43059 19. ? @ 0x00007f35aab92ac3 20. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:53:48.197508 [ 2686 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 14:53:48.212601 [ 3341 ] {} e3036ff5-368c-484b-a22e-55560ab05f73::20000101_20000101_0_0_0_3 (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af80b71 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80746 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d34b5ca 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000002d3486e4 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000002d34827b 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002d36bcf7 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 12. asan_thread_start(void*) @ 0x000000000aa43059 13. ? @ 0x00007f35aab92ac3 14. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:53:48.216615 [ 3341 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {e3036ff5-368c-484b-a22e-55560ab05f73::20000101_20000101_0_0_0_3}: 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af80b71 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80746 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d34b5ca 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000002d3486e4 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000002d34827b 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002d36bcf7 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 12. asan_thread_start(void*) @ 0x000000000aa43059 13. ? @ 0x00007f35aab92ac3 14. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:53:48.365866 [ 3339 ] {} 5c9d53ed-2b19-494d-b534-5ce8bffac442::20000101_20000101_1_1_0_3 (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af80b71 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80746 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d34b5ca 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000002d3486e4 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000002d34827b 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002d36bcf7 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 12. asan_thread_start(void*) @ 0x000000000aa43059 13. ? @ 0x00007f35aab92ac3 14. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:53:48.369980 [ 3339 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {5c9d53ed-2b19-494d-b534-5ce8bffac442::20000101_20000101_1_1_0_3}: 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af80b71 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80746 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d34b5ca 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000002d3486e4 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000002d34827b 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002d36bcf7 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 12. asan_thread_start(void*) @ 0x000000000aa43059 13. ? @ 0x00007f35aab92ac3 14. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:53:48.419378 [ 3331 ] {} e3036ff5-368c-484b-a22e-55560ab05f73::20000201_20000201_0_0_0_2 (MutateFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=0, jobs=0). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af80b71 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80746 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d34b5ca 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000002d3486e4 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000002d34827b 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002d36bcf7 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 12. asan_thread_start(void*) @ 0x000000000aa43059 13. ? @ 0x00007f35aab92ac3 14. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:53:48.422406 [ 3331 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {e3036ff5-368c-484b-a22e-55560ab05f73::20000201_20000201_0_0_0_2}: 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af80b71 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80746 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d34b5ca 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000002d3486e4 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000002d34827b 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002d36bcf7 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 12. asan_thread_start(void*) @ 0x000000000aa43059 13. ? @ 0x00007f35aab92ac3 14. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:53:48.601119 [ 3006 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:53:48.716127 [ 3012 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:53:49.198989 [ 5360 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 14:53:49.603470 [ 3031 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:53:49.720873 [ 3036 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:53:50.263249 [ 4020 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 14:53:50.500248 [ 3331 ] {} 5c9d53ed-2b19-494d-b534-5ce8bffac442::20000101_20000101_0_0_0_4 (MutateFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=773, jobs=722). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af872f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af7b2d1 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af7c3f3 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d36920d 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000002d369e5f 8. ./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) @ 0x000000002959299a 9. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:2185: DB::MutateTask::prepare() @ 0x000000002c9098ab 10. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:2054: DB::MutateTask::execute() @ 0x000000002c907b70 11. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000002ca02f01 12. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x000000002ca00958 13. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000002c427f28 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000002c429675 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7eaf0 16. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001af8a79f 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 19. asan_thread_start(void*) @ 0x000000000aa43059 20. ? @ 0x00007f35aab92ac3 21. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:53:50.514131 [ 3331 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {5c9d53ed-2b19-494d-b534-5ce8bffac442::20000101_20000101_0_0_0_4}: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=773, jobs=722). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af872f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af7b2d1 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af7c3f3 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d36920d 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000002d369e5f 8. ./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) @ 0x000000002959299a 9. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:2185: DB::MutateTask::prepare() @ 0x000000002c9098ab 10. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:2054: DB::MutateTask::execute() @ 0x000000002c907b70 11. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000002ca02f01 12. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x000000002ca00958 13. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000002c427f28 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000002c429675 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7eaf0 16. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001af8a79f 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 19. asan_thread_start(void*) @ 0x000000000aa43059 20. ? @ 0x00007f35aab92ac3 21. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:53:50.605729 [ 3086 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:53:50.656478 [ 3328 ] {} 5c9d53ed-2b19-494d-b534-5ce8bffac442::20000101_20000101_1_1_0_4 (MutateFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af819ed 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80746 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d34b5ca 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:306: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349fbb 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:381: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000002d34bd35 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7eaf0 10. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001af8a79f 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 13. asan_thread_start(void*) @ 0x000000000aa43059 14. ? @ 0x00007f35aab92ac3 15. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:53:50.658051 [ 3328 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {5c9d53ed-2b19-494d-b534-5ce8bffac442::20000101_20000101_1_1_0_4}: 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af819ed 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80746 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d34b5ca 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:306: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349fbb 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:381: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000002d34bd35 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7eaf0 10. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001af8a79f 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 13. asan_thread_start(void*) @ 0x000000000aa43059 14. ? @ 0x00007f35aab92ac3 15. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:53:50.723316 [ 3094 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:53:50.943583 [ 3333 ] {} 5c9d53ed-2b19-494d-b534-5ce8bffac442::20000101_20000101_1_1_0_4 (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af80b71 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80746 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d34b5ca 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000002d3486e4 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000002d34827b 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002d36bcf7 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 12. asan_thread_start(void*) @ 0x000000000aa43059 13. ? @ 0x00007f35aab92ac3 14. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:53:50.950019 [ 3333 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {5c9d53ed-2b19-494d-b534-5ce8bffac442::20000101_20000101_1_1_0_4}: 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af80b71 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80746 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d34b5ca 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000002d3486e4 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000002d34827b 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002d36bcf7 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 12. asan_thread_start(void*) @ 0x000000000aa43059 13. ? @ 0x00007f35aab92ac3 14. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:53:51.422934 [ 4020 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 14:53:51.607833 [ 3123 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:53:51.725429 [ 3129 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:53:52.437547 [ 4016 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 14:53:52.610053 [ 3151 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:53:52.728694 [ 3155 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:53:53.456624 [ 4020 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 14:53:53.613860 [ 3195 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:53:53.730947 [ 3197 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:53:54.489227 [ 4020 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 14:53:54.617137 [ 3230 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:53:54.734495 [ 3233 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:53:55.510370 [ 4020 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 14:53:55.619254 [ 2742 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:53:55.736847 [ 2746 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:53:56.540928 [ 4020 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 14:53:56.621244 [ 2771 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:53:56.738810 [ 2748 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:53:57.564071 [ 4020 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 14:53:57.624392 [ 2791 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:53:57.743392 [ 2796 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:53:58.338845 [ 4021 ] {f35e1554-7295-49dd-94d9-c01760490623} 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.10505.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:48520) (comment: 00505_secure.sh) (in query: SELECT `__table1`.`date` AS `date`, `__table1`.`a` AS `a`, `__table1`.`b` AS `b`, `__table1`.`c` AS `c`, `__table1`.`d` AS `d` FROM `test_3`.`secure1` AS `__table1` ORDER BY `__table1`.`a` 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af819ed 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af82f33 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002c64fc80 7. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1723: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr, unsigned long, std::shared_ptr, std::equal_to, std::allocator>>>, DB::MergeTreeData const&, std::vector> const&, std::shared_ptr, std::optional&, bool) @ 0x000000002de379fd 8. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1437: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000002de3554f 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:0: DB::ReadFromMergeTree::getAnalysisResult() const @ 0x000000002de41345 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:2022: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000002de4404c 11. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000002ddb933c 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000002ddff11e 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000002942117f 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x00000000294209e7 15. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b382fc 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 18. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 22. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 14:53:58.380113 [ 4021 ] {f35e1554-7295-49dd-94d9-c01760490623} 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af819ed 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af82f33 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002c64fc80 7. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1723: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr, unsigned long, std::shared_ptr, std::equal_to, std::allocator>>>, DB::MergeTreeData const&, std::vector> const&, std::shared_ptr, std::optional&, bool) @ 0x000000002de379fd 8. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1437: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000002de3554f 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:0: DB::ReadFromMergeTree::getAnalysisResult() const @ 0x000000002de41345 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:2022: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000002de4404c 11. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000002ddb933c 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000002ddff11e 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000002942117f 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x00000000294209e7 15. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b382fc 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 18. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 22. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 14:53:58.423963 [ 3612 ] {d4277742-c385-4938-b2dd-9150a0205d99} 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.10505.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:56434) (comment: 00505_secure.sh) (in query: SELECT `__table1`.`date` AS `date`, `__table1`.`a` AS `a`, `__table1`.`b` AS `b`, `__table1`.`c` AS `c`, `__table1`.`d` AS `d` FROM `test_3`.`secure1` AS `__table1` ORDER BY `__table1`.`a` 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af819ed 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80746 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d34b5ca 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000002d3486e4 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000002d34827b 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002d36bcf7 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 12. asan_thread_start(void*) @ 0x000000000aa43059 13. ? @ 0x00007f35aab92ac3 14. ? @ 0x00007f35aac24850 2025.09.09 14:53:58.429969 [ 3612 ] {d4277742-c385-4938-b2dd-9150a0205d99} 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af819ed 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80746 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d34b5ca 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000002d3486e4 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000002d34827b 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002d36bcf7 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 12. asan_thread_start(void*) @ 0x000000000aa43059 13. ? @ 0x00007f35aab92ac3 14. ? @ 0x00007f35aac24850 2025.09.09 14:53:58.460328 [ 5360 ] {b2b43b6f-d570-479e-998c-4f97ab8a7232} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=2, jobs=2). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:59518) (comment: 00505_secure.sh) (in query: SELECT * FROM secure1 ORDER BY a;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af80b71 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80746 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d34b5ca 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000002d3486e4 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000002d34827b 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002d36bcf7 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 12. asan_thread_start(void*) @ 0x000000000aa43059 13. ? @ 0x00007f35aab92ac3 14. ? @ 0x00007f35aac24850 2025.09.09 14:53:58.463747 [ 5360 ] {b2b43b6f-d570-479e-998c-4f97ab8a7232} 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af80b71 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80746 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d34b5ca 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000002d3486e4 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000002d34827b 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002d36bcf7 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 12. asan_thread_start(void*) @ 0x000000000aa43059 13. ? @ 0x00007f35aab92ac3 14. ? @ 0x00007f35aac24850 2025.09.09 14:53:58.586686 [ 4022 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 14:53:58.627010 [ 2826 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:53:58.745392 [ 2841 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:53:58.870298 [ 3337 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {166e6d4b-ecec-41a4-ad4a-0c1c77ff9a47::202509_1_84_16}: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=13, jobs=0). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af80b71 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80746 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002c765aab 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:1197: ? @ 0x000000002c7602b8 8. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x000000002c75fc2b 9. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:0: DB::MergeTreeReaderCompact::MergeTreeReaderCompact(std::shared_ptr, DB::NamesAndTypesList, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*, DB::MarkCache*, DB::MarkRanges, DB::MergeTreeReaderSettings, std::map, std::allocator>>, std::function const&, int) @ 0x000000002c7aee03 10. ./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.h:16: DB::MergeTreeReaderCompactSingleBuffer::MergeTreeReaderCompactSingleBuffer&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int&&) @ 0x000000002c5d6d21 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::MergeTreeDataPartCompact::getReader(DB::NamesAndTypesList const&, std::shared_ptr const&, DB::MarkRanges const&, std::unordered_map, std::equal_to, std::allocator>> const&, DB::UncompressedCache*, DB::MarkCache*, std::shared_ptr const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) const @ 0x000000002c5d1037 12. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:169: DB::MergeTreeSequentialSource::MergeTreeSequentialSource(DB::MergeTreeSequentialSourceType, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::vector>, std::optional, bool, bool, bool) @ 0x000000002c80c330 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:35: DB::MergeTreeSequentialSource* std::construct_at[abi:v15007] const&, std::shared_ptr&, std::shared_ptr&, std::vector>&, std::optional, bool, bool&, bool&, DB::MergeTreeSequentialSource*>(DB::MergeTreeSequentialSource*, DB::MergeTreeSequentialSourceType&, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr&, std::shared_ptr&, std::vector>&, std::optional&&, bool&&, bool&, bool&) @ 0x000000002c81320f 14. ./contrib/llvm-project/libcxx/include/__memory/allocator_traits.h:298: DB::createMergeTreeSequentialSource(DB::MergeTreeSequentialSourceType, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::vector>, std::optional, std::shared_ptr>, bool, bool, bool) @ 0x000000002c810812 15. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1136: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::createMergedStream() @ 0x000000002c3dd079 16. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() @ 0x000000002c3d6516 17. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:534: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x000000002c3e2799 18. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::execute() @ 0x000000002c3ef3fe 19. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:0: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000002cc2f4c0 20. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000002c427f28 21. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000002c429675 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7eaf0 23. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001af8a79f 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 26. asan_thread_start(void*) @ 0x000000000aa43059 27. ? @ 0x00007f35aab92ac3 28. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:53:59.629091 [ 2862 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:53:59.690716 [ 3604 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 14:53:59.757623 [ 2869 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:54:00.631117 [ 2900 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:54:00.696089 [ 4022 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 14:54:00.759611 [ 2907 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:54:01.522343 [ 3330 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {8dd55f4d-4394-4634-a445-9c7c9e0f4148::202509_1_41_12}: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=13, 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af80b71 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80746 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002c765aab 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:1197: ? @ 0x000000002c7602b8 8. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x000000002c75fc2b 9. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:0: DB::MergeTreeReaderCompact::MergeTreeReaderCompact(std::shared_ptr, DB::NamesAndTypesList, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*, DB::MarkCache*, DB::MarkRanges, DB::MergeTreeReaderSettings, std::map, std::allocator>>, std::function const&, int) @ 0x000000002c7aee03 10. ./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.h:16: DB::MergeTreeReaderCompactSingleBuffer::MergeTreeReaderCompactSingleBuffer&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int&&) @ 0x000000002c5d6d21 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::MergeTreeDataPartCompact::getReader(DB::NamesAndTypesList const&, std::shared_ptr const&, DB::MarkRanges const&, std::unordered_map, std::equal_to, std::allocator>> const&, DB::UncompressedCache*, DB::MarkCache*, std::shared_ptr const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) const @ 0x000000002c5d1037 12. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:169: DB::MergeTreeSequentialSource::MergeTreeSequentialSource(DB::MergeTreeSequentialSourceType, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::vector>, std::optional, bool, bool, bool) @ 0x000000002c80c330 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:35: DB::MergeTreeSequentialSource* std::construct_at[abi:v15007] const&, std::shared_ptr&, std::shared_ptr&, std::vector>&, std::optional, bool, bool&, bool&, DB::MergeTreeSequentialSource*>(DB::MergeTreeSequentialSource*, DB::MergeTreeSequentialSourceType&, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr&, std::shared_ptr&, std::vector>&, std::optional&&, bool&&, bool&, bool&) @ 0x000000002c81320f 14. ./contrib/llvm-project/libcxx/include/__memory/allocator_traits.h:298: DB::createMergeTreeSequentialSource(DB::MergeTreeSequentialSourceType, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::vector>, std::optional, std::shared_ptr>, bool, bool, bool) @ 0x000000002c810812 15. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1136: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::createMergedStream() @ 0x000000002c3dd079 16. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() @ 0x000000002c3d6516 17. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:534: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x000000002c3e2799 18. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::execute() @ 0x000000002c3ef3fe 19. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:0: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000002cc2f4c0 20. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000002c427f28 21. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000002c429675 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7eaf0 23. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001af8a79f 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 26. asan_thread_start(void*) @ 0x000000000aa43059 27. ? @ 0x00007f35aab92ac3 28. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:54:01.633251 [ 2948 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:54:01.742702 [ 3604 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 14:54:01.767422 [ 2963 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:54:01.910562 [ 3331 ] {} 60dc3db5-2ede-411b-975a-bcdd86455ce4::all_0_0_0_1 (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af80b71 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80746 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d34b5ca 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:306: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349fbb 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:381: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000002d34bd35 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7eaf0 10. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001af8a79f 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 13. asan_thread_start(void*) @ 0x000000000aa43059 14. ? @ 0x00007f35aab92ac3 15. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:54:01.912024 [ 3331 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {60dc3db5-2ede-411b-975a-bcdd86455ce4::all_0_0_0_1}: 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af80b71 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80746 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d34b5ca 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:306: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349fbb 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:381: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000002d34bd35 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7eaf0 10. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001af8a79f 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 13. asan_thread_start(void*) @ 0x000000000aa43059 14. ? @ 0x00007f35aab92ac3 15. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:54:02.027037 [ 3333 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {1e64423d-b43b-45ea-b85e-a97c07ea6431::202509_1_35_7}: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=13, jobs=0). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af80b71 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80746 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002c765aab 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:1197: ? @ 0x000000002c7602b8 8. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x000000002c75fc2b 9. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:0: DB::MergeTreeReaderCompact::MergeTreeReaderCompact(std::shared_ptr, DB::NamesAndTypesList, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*, DB::MarkCache*, DB::MarkRanges, DB::MergeTreeReaderSettings, std::map, std::allocator>>, std::function const&, int) @ 0x000000002c7aee03 10. ./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.h:16: DB::MergeTreeReaderCompactSingleBuffer::MergeTreeReaderCompactSingleBuffer&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int&&) @ 0x000000002c5d6d21 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::MergeTreeDataPartCompact::getReader(DB::NamesAndTypesList const&, std::shared_ptr const&, DB::MarkRanges const&, std::unordered_map, std::equal_to, std::allocator>> const&, DB::UncompressedCache*, DB::MarkCache*, std::shared_ptr const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) const @ 0x000000002c5d1037 12. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:169: DB::MergeTreeSequentialSource::MergeTreeSequentialSource(DB::MergeTreeSequentialSourceType, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::vector>, std::optional, bool, bool, bool) @ 0x000000002c80c330 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:35: DB::MergeTreeSequentialSource* std::construct_at[abi:v15007] const&, std::shared_ptr&, std::shared_ptr&, std::vector>&, std::optional, bool, bool&, bool&, DB::MergeTreeSequentialSource*>(DB::MergeTreeSequentialSource*, DB::MergeTreeSequentialSourceType&, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr&, std::shared_ptr&, std::vector>&, std::optional&&, bool&&, bool&, bool&) @ 0x000000002c81320f 14. ./contrib/llvm-project/libcxx/include/__memory/allocator_traits.h:298: DB::createMergeTreeSequentialSource(DB::MergeTreeSequentialSourceType, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::vector>, std::optional, std::shared_ptr>, bool, bool, bool) @ 0x000000002c810812 15. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1136: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::createMergedStream() @ 0x000000002c3dd079 16. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() @ 0x000000002c3d6516 17. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:534: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x000000002c3e2799 18. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::execute() @ 0x000000002c3ef3fe 19. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:0: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000002cc2f4c0 20. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000002c427f28 21. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000002c429675 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7eaf0 23. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001af8a79f 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 26. asan_thread_start(void*) @ 0x000000000aa43059 27. ? @ 0x00007f35aab92ac3 28. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:54:02.051716 [ 2686 ] {61f36b77-af2a-4654-b8d6-248f12069ec4} 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.10505.altinitytest (altinity build)) (from [::1]:40252) (comment: 00981_topK_topKWeighted_long.sql) (in query: SELECT arraySort(topKWeighted(10)(val1, val2)) FROM topk;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af819ed 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af82f33 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002c64fc80 7. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1723: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr, unsigned long, std::shared_ptr, std::equal_to, std::allocator>>>, DB::MergeTreeData const&, std::vector> const&, std::shared_ptr, std::optional&, bool) @ 0x000000002de379fd 8. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1437: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000002de3554f 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:0: DB::ReadFromMergeTree::getAnalysisResult() const @ 0x000000002de41345 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:2022: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000002de4404c 11. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000002ddb933c 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000002ddff11e 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000002942117f 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x00000000294209e7 15. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b382fc 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 18. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 22. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 14:54:02.055311 [ 2686 ] {61f36b77-af2a-4654-b8d6-248f12069ec4} 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af819ed 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af82f33 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002c64fc80 7. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1723: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr, unsigned long, std::shared_ptr, std::equal_to, std::allocator>>>, DB::MergeTreeData const&, std::vector> const&, std::shared_ptr, std::optional&, bool) @ 0x000000002de379fd 8. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1437: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000002de3554f 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:0: DB::ReadFromMergeTree::getAnalysisResult() const @ 0x000000002de41345 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:2022: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000002de4404c 11. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000002ddb933c 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000002ddff11e 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000002942117f 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x00000000294209e7 15. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b382fc 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 18. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 22. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 14:54:02.635335 [ 2984 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:54:02.769656 [ 2992 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:54:02.806578 [ 3766 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 14:54:03.637645 [ 3032 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:54:03.735261 [ 4022 ] {b14585f2-ff67-4f36-9f9b-69c953e9be14} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=773, jobs=721). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:47642) (comment: 01117_greatest_least_case.sql) (in query: SELECT GREATEST(1, 2);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af872f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af7b2d1 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af7c3f3 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d36920d 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000002d369e5f 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processOrdinaryQuery() @ 0x000000002d18af7b 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d17644a 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 15. asan_thread_start(void*) @ 0x000000000aa43059 16. ? @ 0x00007f35aab92ac3 17. ? @ 0x00007f35aac24850 2025.09.09 14:54:03.739262 [ 4022 ] {b14585f2-ff67-4f36-9f9b-69c953e9be14} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=773, jobs=721). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af872f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af7b2d1 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af7c3f3 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d36920d 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000002d369e5f 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processOrdinaryQuery() @ 0x000000002d18af7b 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d17644a 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 15. asan_thread_start(void*) @ 0x000000000aa43059 16. ? @ 0x00007f35aab92ac3 17. ? @ 0x00007f35aac24850 2025.09.09 14:54:03.771676 [ 3037 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:54:03.818776 [ 4017 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 14:54:04.289595 [ 4022 ] {4b80c919-491c-42f6-9d72-636ce41bb622} executeQuery: Code: 43. DB::Exception: Third argument of function dictHas must be tuple when dictionary is complex and key contains more than 1 attribute.Actual type String.: In scope SELECT dictHas('01280_db.ssd_dict', 'a', tuple('1')). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:47670) (comment: 01280_ssd_complex_key_dictionary.sh) (in query: SELECT dictHas('01280_db.ssd_dict', 'a', tuple('1'));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa91e9a 4. DB::FunctionDictHas::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b5ef123 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aa8c635 6. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aac91d5 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000cccccfb 8. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000cccc1ab 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccccc2a 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccce65c 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd2030 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002839a3af 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000028367bce 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028366290 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283b62c9 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002835ae03 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000028359104 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000028357f0d 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002921bdcc 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&) @ 0x000000002941f313 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&) @ 0x0000000029419aef 22. ./contrib/llvm-project/libcxx/include/vector:432: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000029421f5d 23. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000029344c1b 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*) @ 0x0000000029b3703b 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 27. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 31. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 2025.09.09 14:54:04.295563 [ 4022 ] {4b80c919-491c-42f6-9d72-636ce41bb622} TCPHandler: Code: 43. DB::Exception: Third argument of function dictHas must be tuple when dictionary is complex and key contains more than 1 attribute.Actual type String.: In scope SELECT dictHas('01280_db.ssd_dict', 'a', tuple('1')). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa91e9a 4. DB::FunctionDictHas::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b5ef123 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aa8c635 6. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aac91d5 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000cccccfb 8. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000cccc1ab 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccccc2a 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccce65c 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd2030 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002839a3af 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000028367bce 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028366290 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283b62c9 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002835ae03 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000028359104 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000028357f0d 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002921bdcc 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&) @ 0x000000002941f313 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&) @ 0x0000000029419aef 22. ./contrib/llvm-project/libcxx/include/vector:432: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000029421f5d 23. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000029344c1b 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*) @ 0x0000000029b3703b 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 27. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 31. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 2025.09.09 14:54:04.639791 [ 3071 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:54:04.773497 [ 3088 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:54:04.825634 [ 4022 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 14:54:05.407740 [ 3337 ] {} e8318e8e-0e45-4ef3-bbc0-2ffe7ce0b4d4::all_0_0_0_3 (MutateFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=6, jobs=6). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af80b71 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80746 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d34b5ca 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000002d3486e4 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000002d34827b 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002d36bcf7 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 12. asan_thread_start(void*) @ 0x000000000aa43059 13. ? @ 0x00007f35aab92ac3 14. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:54:05.409399 [ 3337 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {e8318e8e-0e45-4ef3-bbc0-2ffe7ce0b4d4::all_0_0_0_3}: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=6, jobs=6). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af80b71 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80746 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d34b5ca 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000002d3486e4 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000002d34827b 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002d36bcf7 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 12. asan_thread_start(void*) @ 0x000000000aa43059 13. ? @ 0x00007f35aab92ac3 14. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:54:05.409664 [ 5442 ] {} ExternalDictionaries: Could not update cache dictionary '`01280_db`.ssd_dict (0583d1ed-261f-4e6a-98bc-9b8ef6e5d8b1)', next update is scheduled at 2025-09-09 14:54:11: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=3, jobs=0): (while reading column k1): (while reading from part /var/lib/clickhouse/store/20b/20b12f91-ba4e-41d6-8b4a-70b9ee1b60d4/all_2_2_0/ in table `01280_db`.table_for_dict (20b12f91-ba4e-41d6-8b4a-70b9ee1b60d4) located on disk default of type local, from mark 0 with max_rows_to_read = 370): 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af80b71 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80746 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000266005a2 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000265fffb4 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:1197: ? @ 0x00000000265fd4e7 9. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:62: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x00000000265e6fbd 10. ./contrib/llvm-project/libcxx/include/future:1123: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x00000000265e7bb3 11. DB::ReadBuffer::next() @ 0x000000000b528aeb 12. ./src/IO/ReadBuffer.h:0: DB::CompressedReadBufferBase::readCompressedData(unsigned long&, unsigned long&, bool) @ 0x000000002775f11b 13. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:22: DB::CompressedReadBufferFromFile::nextImpl() @ 0x0000000027763d41 14. DB::ReadBuffer::next() @ 0x000000000b528aeb 15. ./build_docker/./src/DataTypes/Serializations/SerializationString.cpp:159: void DB::deserializeBinarySSE2<1>(DB::PODArray, 63ul, 64ul>&, DB::PODArray, 63ul, 64ul>&, DB::ReadBuffer&, unsigned long) @ 0x0000000027c11390 16. ./build_docker/./src/DataTypes/Serializations/SerializationString.cpp:259: DB::SerializationString::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x0000000027c0ec00 17. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:0: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x0000000027aa00db 18. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:196: DB::MergeTreeReaderWide::readData(DB::NameAndTypePair const&, std::shared_ptr const&, COW::immutable_ptr&, unsigned long, bool, unsigned long, unsigned long, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map, std::hash, std::equal_to, std::allocator>>>&, bool) @ 0x000000002c80211e 19. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:158: DB::MergeTreeReaderWide::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c800e8d 20. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:118: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7c9d8a 21. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x000000002c7e0473 22. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x000000002c7dbec3 23. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x000000002c7dbd35 24. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:0: DB::MergeTreeReadTask::read(DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002c82d05b 25. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:38: DB::MergeTreeThreadSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&, DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002de66094 26. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:0: DB::MergeTreeSelectProcessor::read() @ 0x000000002c8242f9 27. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000002de6d77a 28. ./build_docker/./src/Processors/ISource.cpp:0: DB::ISource::work() @ 0x000000002d3290a1 29. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 30. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 31. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:54:05.426918 [ 3326 ] {} 60dc3db5-2ede-411b-975a-bcdd86455ce4::all_0_0_0_3 (MutateFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=10, jobs=10). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af819ed 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80746 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d34b5ca 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000002d3486e4 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000002d34827b 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002d36bcf7 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 12. asan_thread_start(void*) @ 0x000000000aa43059 13. ? @ 0x00007f35aab92ac3 14. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:54:05.429832 [ 3326 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {60dc3db5-2ede-411b-975a-bcdd86455ce4::all_0_0_0_3}: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=10, jobs=10). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af819ed 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80746 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d34b5ca 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000002d3486e4 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000002d34827b 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002d36bcf7 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 12. asan_thread_start(void*) @ 0x000000000aa43059 13. ? @ 0x00007f35aab92ac3 14. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:54:05.617023 [ 3604 ] {c7529156-067b-4a94-9707-57607630d136} executeQuery: Code: 510. DB::Exception: Update failed for dictionary '`01280_db`.ssd_dict (0583d1ed-261f-4e6a-98bc-9b8ef6e5d8b1)': Code: 510. DB::Exception: Update failed for dictionary `01280_db`.ssd_dict (0583d1ed-261f-4e6a-98bc-9b8ef6e5d8b1) : Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=3, jobs=0): (while reading column k1): (while reading from part /var/lib/clickhouse/store/20b/20b12f91-ba4e-41d6-8b4a-70b9ee1b60d4/all_2_2_0/ in table `01280_db`.table_for_dict (20b12f91-ba4e-41d6-8b4a-70b9ee1b60d4) located on disk default of type local, from mark 0 with max_rows_to_read = 370): 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af80b71 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80746 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000266005a2 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000265fffb4 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:1197: ? @ 0x00000000265fd4e7 9. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:62: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x00000000265e6fbd 10. ./contrib/llvm-project/libcxx/include/future:1123: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x00000000265e7bb3 11. DB::ReadBuffer::next() @ 0x000000000b528aeb 12. ./src/IO/ReadBuffer.h:0: DB::CompressedReadBufferBase::readCompressedData(unsigned long&, unsigned long&, bool) @ 0x000000002775f11b 13. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:22: DB::CompressedReadBufferFromFile::nextImpl() @ 0x0000000027763d41 14. DB::ReadBuffer::next() @ 0x000000000b528aeb 15. ./build_docker/./src/DataTypes/Serializations/SerializationString.cpp:159: void DB::deserializeBinarySSE2<1>(DB::PODArray, 63ul, 64ul>&, DB::PODArray, 63ul, 64ul>&, DB::ReadBuffer&, unsigned long) @ 0x0000000027c11390 16. ./build_docker/./src/DataTypes/Serializations/SerializationString.cpp:259: DB::SerializationString::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x0000000027c0ec00 17. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:0: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x0000000027aa00db 18. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:196: DB::MergeTreeReaderWide::readData(DB::NameAndTypePair const&, std::shared_ptr const&, COW::immutable_ptr&, unsigned long, bool, unsigned long, unsigned long, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map, std::hash, std::equal_to, std::allocator>>>&, bool) @ 0x000000002c80211e 19. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:158: DB::MergeTreeReaderWide::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c800e8d 20. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:118: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7c9d8a 21. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x000000002c7e0473 22. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x000000002c7dbec3 23. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x000000002c7dbd35 24. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:0: DB::MergeTreeReadTask::read(DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002c82d05b 25. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:38: DB::MergeTreeThreadSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&, DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002de66094 26. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:0: DB::MergeTreeSelectProcessor::read() @ 0x000000002c8242f9 27. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000002de6d77a 28. ./build_docker/./src/Processors/ISource.cpp:0: DB::ISource::work() @ 0x000000002d3290a1 29. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 30. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 31. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 (version 24.8.14.10505.altinitytest (altinity build)). (CACHE_DICTIONARY_UPDATE_FAIL) (version 24.8.14.10505.altinitytest (altinity build)): In scope SELECT dictGetUInt64('01280_db.ssd_dict', 'a', ('1', toInt32(3))). (CACHE_DICTIONARY_UPDATE_FAIL) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:47690) (comment: 01280_ssd_complex_key_dictionary.sh) (in query: SELECT dictGetUInt64('01280_db.ssd_dict', 'a', tuple('1', toInt32(3)));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000c44a97a 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:117: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)1>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x000000001bb48fd6 5. DB::CacheDictionary<(DB::DictionaryKeyType)1>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x000000001bb2b071 6. DB::CacheDictionary<(DB::DictionaryKeyType)1>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x000000001bb29c43 7. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x000000000b5d6ee9 8. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b5d15c3 9. DB::FunctionDictGetImpl, DB::NameDictGetUInt64, (DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b5ff2f1 10. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aa8c635 11. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aac91d5 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000cccccfb 13. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000cccc1ab 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccccc2a 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccce65c 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd2030 17. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002839a3af 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000028367bce 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028366290 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283b62c9 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002835ae03 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000028359104 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000028357f0d 24. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002921bdcc 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&) @ 0x000000002941f313 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&) @ 0x0000000029419aef 27. ./contrib/llvm-project/libcxx/include/vector:432: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000029421f5d 28. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000029344c1b 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*) @ 0x0000000029b3703b 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 31. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 2025.09.09 14:54:05.622131 [ 3604 ] {c7529156-067b-4a94-9707-57607630d136} TCPHandler: Code: 510. DB::Exception: Update failed for dictionary '`01280_db`.ssd_dict (0583d1ed-261f-4e6a-98bc-9b8ef6e5d8b1)': Code: 510. DB::Exception: Update failed for dictionary `01280_db`.ssd_dict (0583d1ed-261f-4e6a-98bc-9b8ef6e5d8b1) : Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=3, jobs=0): (while reading column k1): (while reading from part /var/lib/clickhouse/store/20b/20b12f91-ba4e-41d6-8b4a-70b9ee1b60d4/all_2_2_0/ in table `01280_db`.table_for_dict (20b12f91-ba4e-41d6-8b4a-70b9ee1b60d4) located on disk default of type local, from mark 0 with max_rows_to_read = 370): 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af80b71 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80746 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000266005a2 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000265fffb4 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:1197: ? @ 0x00000000265fd4e7 9. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:62: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x00000000265e6fbd 10. ./contrib/llvm-project/libcxx/include/future:1123: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x00000000265e7bb3 11. DB::ReadBuffer::next() @ 0x000000000b528aeb 12. ./src/IO/ReadBuffer.h:0: DB::CompressedReadBufferBase::readCompressedData(unsigned long&, unsigned long&, bool) @ 0x000000002775f11b 13. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:22: DB::CompressedReadBufferFromFile::nextImpl() @ 0x0000000027763d41 14. DB::ReadBuffer::next() @ 0x000000000b528aeb 15. ./build_docker/./src/DataTypes/Serializations/SerializationString.cpp:159: void DB::deserializeBinarySSE2<1>(DB::PODArray, 63ul, 64ul>&, DB::PODArray, 63ul, 64ul>&, DB::ReadBuffer&, unsigned long) @ 0x0000000027c11390 16. ./build_docker/./src/DataTypes/Serializations/SerializationString.cpp:259: DB::SerializationString::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x0000000027c0ec00 17. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:0: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x0000000027aa00db 18. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:196: DB::MergeTreeReaderWide::readData(DB::NameAndTypePair const&, std::shared_ptr const&, COW::immutable_ptr&, unsigned long, bool, unsigned long, unsigned long, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map, std::hash, std::equal_to, std::allocator>>>&, bool) @ 0x000000002c80211e 19. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:158: DB::MergeTreeReaderWide::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c800e8d 20. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:118: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7c9d8a 21. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x000000002c7e0473 22. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x000000002c7dbec3 23. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x000000002c7dbd35 24. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:0: DB::MergeTreeReadTask::read(DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002c82d05b 25. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:38: DB::MergeTreeThreadSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&, DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002de66094 26. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:0: DB::MergeTreeSelectProcessor::read() @ 0x000000002c8242f9 27. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000002de6d77a 28. ./build_docker/./src/Processors/ISource.cpp:0: DB::ISource::work() @ 0x000000002d3290a1 29. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 30. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 31. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 (version 24.8.14.10505.altinitytest (altinity build)). (CACHE_DICTIONARY_UPDATE_FAIL) (version 24.8.14.10505.altinitytest (altinity build)): In scope SELECT dictGetUInt64('01280_db.ssd_dict', 'a', ('1', toInt32(3))). (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000c44a97a 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:117: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)1>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x000000001bb48fd6 5. DB::CacheDictionary<(DB::DictionaryKeyType)1>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x000000001bb2b071 6. DB::CacheDictionary<(DB::DictionaryKeyType)1>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x000000001bb29c43 7. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x000000000b5d6ee9 8. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b5d15c3 9. DB::FunctionDictGetImpl, DB::NameDictGetUInt64, (DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b5ff2f1 10. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aa8c635 11. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aac91d5 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000cccccfb 13. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000cccc1ab 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccccc2a 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccce65c 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd2030 17. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002839a3af 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000028367bce 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028366290 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283b62c9 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002835ae03 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000028359104 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000028357f0d 24. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002921bdcc 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&) @ 0x000000002941f313 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&) @ 0x0000000029419aef 27. ./contrib/llvm-project/libcxx/include/vector:432: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000029421f5d 28. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000029344c1b 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*) @ 0x0000000029b3703b 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 31. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 2025.09.09 14:54:05.647273 [ 3125 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:54:05.775826 [ 3129 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:54:05.854456 [ 3604 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 14:54:06.450053 [ 3604 ] {8c7813e8-1581-4a11-93d8-fdf3ad8134a3} executeQuery: Code: 53. DB::Exception: Dictionary `01280_db`.ssd_dict (0583d1ed-261f-4e6a-98bc-9b8ef6e5d8b1) key lookup structure does not match, expected (String, Int32): In scope SELECT dictGetUInt64('01280_db.ssd_dict', 'a', tuple(toInt32(3))). (TYPE_MISMATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:47720) (comment: 01280_ssd_complex_key_dictionary.sh) (in query: SELECT dictGetUInt64('01280_db.ssd_dict', 'a', tuple(toInt32(3)));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa91e9a 4. ./src/Dictionaries/IDictionary.h:151: DB::IDictionary::convertKeyColumns(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&, std::vector, std::allocator>>&) const @ 0x000000001b64fde8 5. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b5d1275 6. DB::FunctionDictGetImpl, DB::NameDictGetUInt64, (DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b5ff2f1 7. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aa8c635 8. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aac91d5 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000cccccfb 10. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000cccc1ab 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccccc2a 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccce65c 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd2030 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002839a3af 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000028367bce 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028366290 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283b62c9 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002835ae03 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000028359104 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000028357f0d 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002921bdcc 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&) @ 0x000000002941f313 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&) @ 0x0000000029419aef 24. ./contrib/llvm-project/libcxx/include/vector:432: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000029421f5d 25. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000029344c1b 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*) @ 0x0000000029b3703b 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 28. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 29. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 2025.09.09 14:54:06.452446 [ 3604 ] {8c7813e8-1581-4a11-93d8-fdf3ad8134a3} TCPHandler: Code: 53. DB::Exception: Dictionary `01280_db`.ssd_dict (0583d1ed-261f-4e6a-98bc-9b8ef6e5d8b1) key lookup structure does not match, expected (String, Int32): In scope SELECT dictGetUInt64('01280_db.ssd_dict', 'a', tuple(toInt32(3))). (TYPE_MISMATCH), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa91e9a 4. ./src/Dictionaries/IDictionary.h:151: DB::IDictionary::convertKeyColumns(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&, std::vector, std::allocator>>&) const @ 0x000000001b64fde8 5. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b5d1275 6. DB::FunctionDictGetImpl, DB::NameDictGetUInt64, (DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b5ff2f1 7. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aa8c635 8. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aac91d5 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000cccccfb 10. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000cccc1ab 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccccc2a 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccce65c 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd2030 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002839a3af 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000028367bce 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028366290 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283b62c9 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002835ae03 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000028359104 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000028357f0d 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002921bdcc 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&) @ 0x000000002941f313 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&) @ 0x0000000029419aef 24. ./contrib/llvm-project/libcxx/include/vector:432: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000029421f5d 25. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000029344c1b 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*) @ 0x0000000029b3703b 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 28. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 29. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 2025.09.09 14:54:06.518146 [ 3327 ] {} e8318e8e-0e45-4ef3-bbc0-2ffe7ce0b4d4::all_0_0_0_3 (MutateFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=10, jobs=10). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af819ed 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80746 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d34b5ca 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:306: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349fbb 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:381: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000002d34bd35 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7eaf0 10. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001af8a79f 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 13. asan_thread_start(void*) @ 0x000000000aa43059 14. ? @ 0x00007f35aab92ac3 15. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:54:06.574504 [ 3327 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {e8318e8e-0e45-4ef3-bbc0-2ffe7ce0b4d4::all_0_0_0_3}: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=10, jobs=10). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af819ed 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80746 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d34b5ca 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:306: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349fbb 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:381: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000002d34bd35 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7eaf0 10. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001af8a79f 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 13. asan_thread_start(void*) @ 0x000000000aa43059 14. ? @ 0x00007f35aab92ac3 15. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:54:06.650711 [ 3151 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:54:06.778146 [ 3158 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:54:06.887451 [ 3604 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 14:54:07.652472 [ 3183 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:54:07.780195 [ 3193 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:54:07.964711 [ 4022 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 14:54:08.654401 [ 3233 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:54:08.782104 [ 3226 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:54:08.942986 [ 4017 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 14:54:09.656414 [ 2751 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:54:09.784199 [ 2743 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:54:09.909975 [ 5212 ] {} ExternalDictionaries: Could not update cache dictionary '`01280_db`.ssd_dict (6ce8a11c-7ebc-4397-a77b-8c9be2181e85)', next update is scheduled at 2025-09-09 14:54:14: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=13, 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af80b71 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80746 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002c765aab 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:1197: ? @ 0x000000002c7602b8 8. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x000000002c75fc2b 9. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:0: DB::MergeTreeReaderWide::addStream(DB::ISerialization::SubstreamPath const&, String const&) @ 0x000000002c802c31 10. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:0: void std::__function::__policy_invoker::__call_impl const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x000000002c804a95 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000027a9e455 12. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:106: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x0000000027a9ea65 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:100: DB::MergeTreeReaderWide::addStreams(DB::NameAndTypePair const&, std::shared_ptr const&) @ 0x000000002c7fe815 14. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:0: DB::MergeTreeReaderWide::MergeTreeReaderWide(std::shared_ptr, DB::NamesAndTypesList, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*, DB::MarkCache*, DB::MarkRanges, DB::MergeTreeReaderSettings, std::map, std::allocator>>, std::function const&, int) @ 0x000000002c7fdeea 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) @ 0x000000002c5eb9c6 16. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWide.cpp:43: DB::MergeTreeDataPartWide::getReader(DB::NamesAndTypesList const&, std::shared_ptr const&, DB::MarkRanges const&, std::unordered_map, std::equal_to, std::allocator>> const&, DB::UncompressedCache*, DB::MarkCache*, std::shared_ptr const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) const @ 0x000000002c5e354e 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:44: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x000000002c82acda 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:295: DB::MergeTreeReadPoolBase::createTask(std::shared_ptr, DB::MarkRanges, DB::MergeTreeReadTask*) const @ 0x000000002de9c5f2 19. ./build_docker/./src/Storages/MergeTree/MergeTreeReadPool.cpp:144: DB::MergeTreeReadPool::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x000000002def1bcc 20. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:0: DB::MergeTreeSelectProcessor::read() @ 0x000000002c8241d2 21. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000002de6d77a 22. ./build_docker/./src/Processors/ISource.cpp:0: DB::ISource::work() @ 0x000000002d3290a1 23. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 28. DB::CacheDictionary<(DB::DictionaryKeyType)1>::update(std::shared_ptr>) @ 0x000000001bb3322b 29. void std::__function::__policy_invoker>)>::__call_impl::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>), void (std::shared_ptr>)>>(std::__function::__policy_storage const*, std::shared_ptr>&&) @ 0x000000001bb41f4c 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)1>::updateThreadFunction() @ 0x000000001bb492f3 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7eaf0 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:54:10.027667 [ 3722 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 14:54:10.112278 [ 3766 ] {4d9740ba-ef50-4ae2-af69-3595a3dd29f1} executeQuery: Code: 510. DB::Exception: Update failed for dictionary '`01280_db`.ssd_dict (6ce8a11c-7ebc-4397-a77b-8c9be2181e85)': Code: 510. DB::Exception: Update failed for dictionary `01280_db`.ssd_dict (6ce8a11c-7ebc-4397-a77b-8c9be2181e85) : Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=13, 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af80b71 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80746 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002c765aab 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:1197: ? @ 0x000000002c7602b8 8. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x000000002c75fc2b 9. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:0: DB::MergeTreeReaderWide::addStream(DB::ISerialization::SubstreamPath const&, String const&) @ 0x000000002c802c31 10. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:0: void std::__function::__policy_invoker::__call_impl const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x000000002c804a95 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000027a9e455 12. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:106: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x0000000027a9ea65 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:100: DB::MergeTreeReaderWide::addStreams(DB::NameAndTypePair const&, std::shared_ptr const&) @ 0x000000002c7fe815 14. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:0: DB::MergeTreeReaderWide::MergeTreeReaderWide(std::shared_ptr, DB::NamesAndTypesList, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*, DB::MarkCache*, DB::MarkRanges, DB::MergeTreeReaderSettings, std::map, std::allocator>>, std::function const&, int) @ 0x000000002c7fdeea 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) @ 0x000000002c5eb9c6 16. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWide.cpp:43: DB::MergeTreeDataPartWide::getReader(DB::NamesAndTypesList const&, std::shared_ptr const&, DB::MarkRanges const&, std::unordered_map, std::equal_to, std::allocator>> const&, DB::UncompressedCache*, DB::MarkCache*, std::shared_ptr const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) const @ 0x000000002c5e354e 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:44: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x000000002c82acda 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:295: DB::MergeTreeReadPoolBase::createTask(std::shared_ptr, DB::MarkRanges, DB::MergeTreeReadTask*) const @ 0x000000002de9c5f2 19. ./build_docker/./src/Storages/MergeTree/MergeTreeReadPool.cpp:144: DB::MergeTreeReadPool::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x000000002def1bcc 20. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:0: DB::MergeTreeSelectProcessor::read() @ 0x000000002c8241d2 21. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000002de6d77a 22. ./build_docker/./src/Processors/ISource.cpp:0: DB::ISource::work() @ 0x000000002d3290a1 23. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 28. DB::CacheDictionary<(DB::DictionaryKeyType)1>::update(std::shared_ptr>) @ 0x000000001bb3322b 29. void std::__function::__policy_invoker>)>::__call_impl::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>), void (std::shared_ptr>)>>(std::__function::__policy_storage const*, std::shared_ptr>&&) @ 0x000000001bb41f4c 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)1>::updateThreadFunction() @ 0x000000001bb492f3 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7eaf0 (version 24.8.14.10505.altinitytest (altinity build)). (CACHE_DICTIONARY_UPDATE_FAIL) (version 24.8.14.10505.altinitytest (altinity build)): while executing 'FUNCTION dictGetUInt64('01280_db.ssd_dict'_String :: 2, 'a'_String :: 3, tuple(__table1.k1, __table1.k2) :: 1) -> dictGetUInt64('01280_db.ssd_dict'_String, 'a'_String, tuple(__table1.k1, __table1.k2)) UInt64 : 0'. (CACHE_DICTIONARY_UPDATE_FAIL) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:47764) (comment: 01280_ssd_complex_key_dictionary.sh) (in query: SELECT sum(dictGetUInt64('01280_db.ssd_dict', 'a', (k1, k2))) FROM 01280_db.keys_table;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000c44a97a 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:117: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)1>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x000000001bb48fd6 5. DB::CacheDictionary<(DB::DictionaryKeyType)1>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x000000001bb2b071 6. DB::CacheDictionary<(DB::DictionaryKeyType)1>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x000000001bb29c43 7. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x000000000b5d6ee9 8. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b5d15c3 9. DB::FunctionDictGetImpl, DB::NameDictGetUInt64, (DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b5ff2f1 10. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aac9135 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000cccce5b 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccce65c 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd2030 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x00000000286fc2bd 15. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000002d9c29ae 16. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 17. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 18. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 20. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:381: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000002d34bd35 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7eaf0 22. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001af8a79f 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 25. asan_thread_start(void*) @ 0x000000000aa43059 26. ? @ 0x00007f35aab92ac3 27. ? @ 0x00007f35aac24850 2025.09.09 14:54:10.142140 [ 3766 ] {4d9740ba-ef50-4ae2-af69-3595a3dd29f1} TCPHandler: Code: 510. DB::Exception: Update failed for dictionary '`01280_db`.ssd_dict (6ce8a11c-7ebc-4397-a77b-8c9be2181e85)': Code: 510. DB::Exception: Update failed for dictionary `01280_db`.ssd_dict (6ce8a11c-7ebc-4397-a77b-8c9be2181e85) : Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=13, 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af80b71 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80746 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002c765aab 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:1197: ? @ 0x000000002c7602b8 8. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x000000002c75fc2b 9. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:0: DB::MergeTreeReaderWide::addStream(DB::ISerialization::SubstreamPath const&, String const&) @ 0x000000002c802c31 10. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:0: void std::__function::__policy_invoker::__call_impl const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x000000002c804a95 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000027a9e455 12. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:106: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x0000000027a9ea65 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:100: DB::MergeTreeReaderWide::addStreams(DB::NameAndTypePair const&, std::shared_ptr const&) @ 0x000000002c7fe815 14. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:0: DB::MergeTreeReaderWide::MergeTreeReaderWide(std::shared_ptr, DB::NamesAndTypesList, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*, DB::MarkCache*, DB::MarkRanges, DB::MergeTreeReaderSettings, std::map, std::allocator>>, std::function const&, int) @ 0x000000002c7fdeea 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) @ 0x000000002c5eb9c6 16. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWide.cpp:43: DB::MergeTreeDataPartWide::getReader(DB::NamesAndTypesList const&, std::shared_ptr const&, DB::MarkRanges const&, std::unordered_map, std::equal_to, std::allocator>> const&, DB::UncompressedCache*, DB::MarkCache*, std::shared_ptr const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) const @ 0x000000002c5e354e 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:44: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x000000002c82acda 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:295: DB::MergeTreeReadPoolBase::createTask(std::shared_ptr, DB::MarkRanges, DB::MergeTreeReadTask*) const @ 0x000000002de9c5f2 19. ./build_docker/./src/Storages/MergeTree/MergeTreeReadPool.cpp:144: DB::MergeTreeReadPool::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x000000002def1bcc 20. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:0: DB::MergeTreeSelectProcessor::read() @ 0x000000002c8241d2 21. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000002de6d77a 22. ./build_docker/./src/Processors/ISource.cpp:0: DB::ISource::work() @ 0x000000002d3290a1 23. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 28. DB::CacheDictionary<(DB::DictionaryKeyType)1>::update(std::shared_ptr>) @ 0x000000001bb3322b 29. void std::__function::__policy_invoker>)>::__call_impl::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>), void (std::shared_ptr>)>>(std::__function::__policy_storage const*, std::shared_ptr>&&) @ 0x000000001bb41f4c 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)1>::updateThreadFunction() @ 0x000000001bb492f3 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7eaf0 (version 24.8.14.10505.altinitytest (altinity build)). (CACHE_DICTIONARY_UPDATE_FAIL) (version 24.8.14.10505.altinitytest (altinity build)): while executing 'FUNCTION dictGetUInt64('01280_db.ssd_dict'_String :: 2, 'a'_String :: 3, tuple(__table1.k1, __table1.k2) :: 1) -> dictGetUInt64('01280_db.ssd_dict'_String, 'a'_String, tuple(__table1.k1, __table1.k2)) UInt64 : 0'. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000c44a97a 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:117: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)1>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x000000001bb48fd6 5. DB::CacheDictionary<(DB::DictionaryKeyType)1>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x000000001bb2b071 6. DB::CacheDictionary<(DB::DictionaryKeyType)1>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x000000001bb29c43 7. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x000000000b5d6ee9 8. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b5d15c3 9. DB::FunctionDictGetImpl, DB::NameDictGetUInt64, (DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b5ff2f1 10. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aac9135 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000cccce5b 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccce65c 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd2030 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x00000000286fc2bd 15. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000002d9c29ae 16. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 17. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 18. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 20. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:381: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000002d34bd35 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7eaf0 22. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001af8a79f 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 25. asan_thread_start(void*) @ 0x000000000aa43059 26. ? @ 0x00007f35aab92ac3 27. ? @ 0x00007f35aac24850 2025.09.09 14:54:10.230279 [ 3337 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {b2866e3d-697f-407e-a02c-018043ee7457::202509_1_51_10}: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=13, 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af80b71 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80746 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002c765aab 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:1197: ? @ 0x000000002c7602b8 8. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x000000002c75fc2b 9. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:0: DB::MergeTreeReaderCompact::MergeTreeReaderCompact(std::shared_ptr, DB::NamesAndTypesList, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*, DB::MarkCache*, DB::MarkRanges, DB::MergeTreeReaderSettings, std::map, std::allocator>>, std::function const&, int) @ 0x000000002c7aee03 10. ./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.h:16: DB::MergeTreeReaderCompactSingleBuffer::MergeTreeReaderCompactSingleBuffer&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int&&) @ 0x000000002c5d6d21 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::MergeTreeDataPartCompact::getReader(DB::NamesAndTypesList const&, std::shared_ptr const&, DB::MarkRanges const&, std::unordered_map, std::equal_to, std::allocator>> const&, DB::UncompressedCache*, DB::MarkCache*, std::shared_ptr const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) const @ 0x000000002c5d1037 12. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:169: DB::MergeTreeSequentialSource::MergeTreeSequentialSource(DB::MergeTreeSequentialSourceType, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::vector>, std::optional, bool, bool, bool) @ 0x000000002c80c330 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:35: DB::MergeTreeSequentialSource* std::construct_at[abi:v15007] const&, std::shared_ptr&, std::shared_ptr&, std::vector>&, std::optional, bool, bool&, bool&, DB::MergeTreeSequentialSource*>(DB::MergeTreeSequentialSource*, DB::MergeTreeSequentialSourceType&, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr&, std::shared_ptr&, std::vector>&, std::optional&&, bool&&, bool&, bool&) @ 0x000000002c81320f 14. ./contrib/llvm-project/libcxx/include/__memory/allocator_traits.h:298: DB::createMergeTreeSequentialSource(DB::MergeTreeSequentialSourceType, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::vector>, std::optional, std::shared_ptr>, bool, bool, bool) @ 0x000000002c810812 15. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1136: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::createMergedStream() @ 0x000000002c3dd079 16. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() @ 0x000000002c3d6516 17. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:534: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x000000002c3e2799 18. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::execute() @ 0x000000002c3ef3fe 19. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:0: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000002cc2f4c0 20. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000002c427f28 21. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000002c429675 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7eaf0 23. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001af8a79f 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 26. asan_thread_start(void*) @ 0x000000000aa43059 27. ? @ 0x00007f35aab92ac3 28. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:54:10.659844 [ 2783 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:54:10.790423 [ 2791 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:54:11.070347 [ 2688 ] {ece4c4c5-79c1-4179-af6e-f1878d531300} executeQuery: Code: 62. DB::Exception: Cannot TRUNCATE dictionary. (SYNTAX_ERROR) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:35816) (comment: 01280_ssd_complex_key_dictionary.sh) (in query: DROP DATABASE IF EXISTS 01280_db;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aac868e 4. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:262: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x00000000291f1adc 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>>>&) @ 0x00000000291f510c 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:361: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000291edc97 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x00000000291ebf11 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x00000000291eb7ed 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b382fc 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 14:54:11.100819 [ 2688 ] {ece4c4c5-79c1-4179-af6e-f1878d531300} 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aac868e 4. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:262: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x00000000291f1adc 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>>>&) @ 0x00000000291f510c 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:361: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000291edc97 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x00000000291ebf11 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x00000000291eb7ed 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b382fc 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 14:54:11.124891 [ 3722 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 14:54:11.581119 [ 2805 ] {} 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af819ed 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80746 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000263a174e 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000286c6b9c 8. ./contrib/llvm-project/libcxx/include/vector:590: DB::DatabaseCatalog::dropTableDataTask() @ 0x00000000286c7466 9. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 11. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 14. asan_thread_start(void*) @ 0x000000000aa43059 15. ? @ 0x00007f35aab92ac3 16. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:54:11.661861 [ 2819 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:54:11.794314 [ 2832 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:54:12.200037 [ 4017 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 14:54:12.663738 [ 2848 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:54:12.796407 [ 2847 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:54:13.222102 [ 2688 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 14:54:13.665703 [ 2870 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:54:13.798509 [ 2877 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:54:14.209439 [ 2688 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 14:54:14.736825 [ 2898 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:54:14.800549 [ 2899 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:54:15.223529 [ 2688 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 14:54:15.739433 [ 2916 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:54:15.802603 [ 2921 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:54:16.283140 [ 4017 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 14:54:16.741730 [ 2934 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:54:16.804710 [ 2938 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:54:17.264556 [ 2688 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 14:54:17.743697 [ 2949 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:54:17.808578 [ 2955 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:54:18.306536 [ 4017 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 14:54:18.745724 [ 2980 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:54:18.810601 [ 2978 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:54:19.343261 [ 3722 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 14:54:19.642525 [ 3334 ] {ba3c0592-4a56-41cc-9d51-b973682afa82::all_1_1_0_2} MutatePlainMergeTreeTask: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=1, jobs=1). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:54:19.649223 [ 3334 ] {ba3c0592-4a56-41cc-9d51-b973682afa82::all_1_1_0_2} 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af80b71 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80746 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d34b5ca 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000002d3486e4 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000002d34827b 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002d36bcf7 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 12. asan_thread_start(void*) @ 0x000000000aa43059 13. ? @ 0x00007f35aab92ac3 14. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:54:19.697176 [ 4017 ] {e887c4cb-47e9-458d-8cf3-2c70ab067a9a} executeQuery: Code: 341. DB::Exception: Mutation mutation_2.txt was killed. (UNFINISHED) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:60348) (comment: 03144_alter_column_and_read.sql) (in query: alter table tab update x = x + sleepEachRow(0.1) where 1;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/MergeTree/MergeTreeMutationStatus.cpp:22: DB::checkMutationStatus(std::optional&, std::set, std::allocator> const&) @ 0x000000002c76d111 5. ./build_docker/./src/Storages/StorageMergeTree.cpp:0: DB::StorageMergeTree::waitForMutation(long, String const&, bool) @ 0x000000002cbbc805 6. ./contrib/llvm-project/libcxx/include/string:1499: DB::StorageMergeTree::mutate(DB::MutationCommands const&, std::shared_ptr) @ 0x000000002cbbe409 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000029174a1c 8. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x0000000029170711 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b382fc 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 14:54:19.722514 [ 4017 ] {e887c4cb-47e9-458d-8cf3-2c70ab067a9a} TCPHandler: Code: 341. DB::Exception: Mutation mutation_2.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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/MergeTree/MergeTreeMutationStatus.cpp:22: DB::checkMutationStatus(std::optional&, std::set, std::allocator> const&) @ 0x000000002c76d111 5. ./build_docker/./src/Storages/StorageMergeTree.cpp:0: DB::StorageMergeTree::waitForMutation(long, String const&, bool) @ 0x000000002cbbc805 6. ./contrib/llvm-project/libcxx/include/string:1499: DB::StorageMergeTree::mutate(DB::MutationCommands const&, std::shared_ptr) @ 0x000000002cbbe409 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000029174a1c 8. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x0000000029170711 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b382fc 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 14:54:19.747525 [ 2999 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:54:19.813985 [ 2992 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:54:20.320420 [ 4021 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 14:54:20.749608 [ 3015 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:54:20.816173 [ 3024 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:54:21.331665 [ 2688 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 14:54:21.751925 [ 3038 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:54:21.818541 [ 3039 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:54:22.410459 [ 3640 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 14:54:22.762847 [ 3045 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:54:22.820638 [ 3053 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:54:22.919217 [ 3722 ] {test_3_test_benchmark_29e1878a-411e-47c7-91ba-490bdb79528d} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=773, jobs=733). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:60446) (comment: 03143_benchmark_query_id_prefix.sh) (in query: SELECT 1), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af872f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af7b2d1 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af7c3f3 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d36920d 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000002d369e5f 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processOrdinaryQuery() @ 0x000000002d18af7b 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d17644a 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 15. asan_thread_start(void*) @ 0x000000000aa43059 16. ? @ 0x00007f35aab92ac3 17. ? @ 0x00007f35aac24850 2025.09.09 14:54:22.921403 [ 3722 ] {test_3_test_benchmark_29e1878a-411e-47c7-91ba-490bdb79528d} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=773, 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af872f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af7b2d1 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af7c3f3 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d36920d 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000002d369e5f 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processOrdinaryQuery() @ 0x000000002d18af7b 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d17644a 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 15. asan_thread_start(void*) @ 0x000000000aa43059 16. ? @ 0x00007f35aab92ac3 17. ? @ 0x00007f35aac24850 2025.09.09 14:54:23.430253 [ 3640 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 14:54:23.764664 [ 3072 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:54:23.823483 [ 3070 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:54:24.385227 [ 3640 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 14:54:24.480347 [ 2688 ] {e799fbed-a467-4bd1-9b96-943c12fe1701} 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.10505.altinitytest (altinity build)) (from [::1]:60484) (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String const&, String&&, String&&) @ 0x00000000283c6735 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3684: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002836a1d4 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028366290 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283b62c9 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002835ae03 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000028359104 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000028357f0d 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002921bdcc 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&) @ 0x000000002941f313 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&) @ 0x0000000029419aef 13. ./contrib/llvm-project/libcxx/include/vector:432: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000029421f5d 14. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000029344c1b 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*) @ 0x0000000029b3703b 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 18. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 22. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 14:54:24.504508 [ 2688 ] {e799fbed-a467-4bd1-9b96-943c12fe1701} 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String const&, String&&, String&&) @ 0x00000000283c6735 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3684: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002836a1d4 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028366290 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283b62c9 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002835ae03 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000028359104 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000028357f0d 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002921bdcc 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&) @ 0x000000002941f313 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&) @ 0x0000000029419aef 13. ./contrib/llvm-project/libcxx/include/vector:432: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000029421f5d 14. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000029344c1b 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*) @ 0x0000000029b3703b 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 18. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 22. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 14:54:24.766820 [ 3097 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:54:24.827040 [ 3100 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:54:25.415039 [ 3640 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 14:54:25.769481 [ 3123 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:54:25.829220 [ 3124 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:54:26.159414 [ 2686 ] {504cc3fc-1c20-43e5-90e4-5a87618dfac2} 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.10505.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:44266) (comment: 03203_hive_style_partitioning.sh) (in query: SELECT __table1.column1 AS column1, __table1.column0 AS column0 FROM s3Cluster(test_cluster_one_shard_three_replicas_localhost, 'http://localhost:11111/test/hive_partitioning/column0=Elizabeth/sample.parquet', 'Parquet', '`column1` Nullable(String)') AS __table1 LIMIT _CAST(10, 'UInt64')), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af819ed 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80746 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000267fd682 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000267fd094 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:1197: ? @ 0x00000000267e6c01 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000267d95d5 10. ./build_docker/./src/Storages/ObjectStorage/StorageObjectStorage.cpp:233: DB::(anonymous namespace)::ReadFromObjectStorageStep::createIterator(DB::ActionsDAG::Node const*) @ 0x00000000267c14a8 11. ./build_docker/./src/Storages/ObjectStorage/StorageObjectStorage.cpp:172: DB::(anonymous namespace)::ReadFromObjectStorageStep::applyFilters(DB::ActionDAGNodes) @ 0x00000000267c0ef8 12. ./contrib/llvm-project/libcxx/include/vector:590: DB::SourceStepWithFilter::applyFilters() @ 0x000000002df93a35 13. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizePrimaryKeyConditionAndLimit.cpp:0: DB::QueryPlanOptimizations::optimizePrimaryKeyConditionAndLimit(std::vector> const&) @ 0x000000002df9366a 14. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:122: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x000000002df62d06 15. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:507: DB::QueryPlan::optimize(DB::QueryPlanOptimizationSettings const&) @ 0x000000002de001ca 16. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:36: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000002ddfec4b 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000002942117f 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x00000000294209e7 19. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b382fc 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 21. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 22. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 26. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 27. asan_thread_start(void*) @ 0x000000000aa43059 28. ? @ 0x00007f35aab92ac3 29. ? @ 0x00007f35aac24850 2025.09.09 14:54:26.164639 [ 2686 ] {504cc3fc-1c20-43e5-90e4-5a87618dfac2} 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af819ed 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80746 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000267fd682 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000267fd094 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:1197: ? @ 0x00000000267e6c01 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000267d95d5 10. ./build_docker/./src/Storages/ObjectStorage/StorageObjectStorage.cpp:233: DB::(anonymous namespace)::ReadFromObjectStorageStep::createIterator(DB::ActionsDAG::Node const*) @ 0x00000000267c14a8 11. ./build_docker/./src/Storages/ObjectStorage/StorageObjectStorage.cpp:172: DB::(anonymous namespace)::ReadFromObjectStorageStep::applyFilters(DB::ActionDAGNodes) @ 0x00000000267c0ef8 12. ./contrib/llvm-project/libcxx/include/vector:590: DB::SourceStepWithFilter::applyFilters() @ 0x000000002df93a35 13. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizePrimaryKeyConditionAndLimit.cpp:0: DB::QueryPlanOptimizations::optimizePrimaryKeyConditionAndLimit(std::vector> const&) @ 0x000000002df9366a 14. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:122: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x000000002df62d06 15. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:507: DB::QueryPlan::optimize(DB::QueryPlanOptimizationSettings const&) @ 0x000000002de001ca 16. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:36: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000002ddfec4b 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000002942117f 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x00000000294209e7 19. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b382fc 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 21. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 22. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 26. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 27. asan_thread_start(void*) @ 0x000000000aa43059 28. ? @ 0x00007f35aab92ac3 29. ? @ 0x00007f35aac24850 2025.09.09 14:54:26.257938 [ 2688 ] {ad986ab4-d5d9-4a33-b665-8c93c58f87b5} executeQuery: Code: 439. DB::Exception: Received from 127.0.0.1:9000. DB::Exception: Cannot schedule a task: failed to start the thread (threads=1, jobs=1). Stack trace: 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af819ed 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80746 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000267fd682 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000267fd094 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:1197: ? @ 0x00000000267e6c01 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000267d95d5 10. ./build_docker/./src/Storages/ObjectStorage/StorageObjectStorage.cpp:233: DB::(anonymous namespace)::ReadFromObjectStorageStep::createIterator(DB::ActionsDAG::Node const*) @ 0x00000000267c14a8 11. ./build_docker/./src/Storages/ObjectStorage/StorageObjectStorage.cpp:172: DB::(anonymous namespace)::ReadFromObjectStorageStep::applyFilters(DB::ActionDAGNodes) @ 0x00000000267c0ef8 12. ./contrib/llvm-project/libcxx/include/vector:590: DB::SourceStepWithFilter::applyFilters() @ 0x000000002df93a35 13. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizePrimaryKeyConditionAndLimit.cpp:0: DB::QueryPlanOptimizations::optimizePrimaryKeyConditionAndLimit(std::vector> const&) @ 0x000000002df9366a 14. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:122: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x000000002df62d06 15. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:507: DB::QueryPlan::optimize(DB::QueryPlanOptimizationSettings const&) @ 0x000000002de001ca 16. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:36: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000002ddfec4b 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000002942117f 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x00000000294209e7 19. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b382fc 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 21. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 22. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 26. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 27. asan_thread_start(void*) @ 0x000000000aa43059 28. ? @ 0x00007f35aab92ac3 29. ? @ 0x00007f35aac24850 : While executing Remote. (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:60500) (comment: 03203_hive_style_partitioning.sh) (in query: SELECT *, column0 FROM s3Cluster(test_cluster_one_shard_three_replicas_localhost, 'http://localhost:11111/test/hive_partitioning/column0=Elizabeth/sample.parquet') LIMIT 10;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. ./contrib/llvm-project/libcxx/include/string:1499: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x000000001aeb974e 3. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::Connection::receiveException() const @ 0x000000002cee6c6a 4. ./build_docker/./src/Client/Connection.cpp:0: DB::Connection::receivePacket() @ 0x000000002cef780e 5. ./build_docker/./src/Client/MultiplexedConnections.cpp:340: DB::MultiplexedConnections::receivePacketUnlocked(std::function) @ 0x000000002cf8e09e 6. ./build_docker/./src/QueryPipeline/RemoteQueryExecutorReadContext.cpp:0: DB::RemoteQueryExecutorReadContext::Task::run(std::function, std::function) @ 0x00000000278ad616 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000278ab436 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000278aaa44 9. ./contrib/boost/boost/context/fiber_ucontext.hpp:82: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x00000000278a8394 2025.09.09 14:54:26.277770 [ 3766 ] {} ServerErrorHandler: Code: 210. DB::NetException: Connection reset by peer, while reading from socket (peer: [::ffff:127.0.0.1]:55232, local: [::ffff:127.0.0.3]:9000). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 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&&) @ 0x000000001b0b7a5f 3. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:83: DB::ReadBufferFromPocoSocketBase::socketReceiveBytesImpl(char*, unsigned long) @ 0x000000001b0b6042 4. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:107: DB::ReadBufferFromPocoSocketBase::nextImpl() @ 0x000000001b0b6b84 5. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:103: DB::ReadBufferFromPocoSocketChunked::nextImpl() @ 0x000000002cf045f6 6. DB::ReadBuffer::next() @ 0x000000000b528aeb 7. ./build_docker/./src/Server/TCPHandler.cpp:383: DB::TCPHandler::runImpl() @ 0x000000002d174fd3 8. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 12. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 13. asan_thread_start(void*) @ 0x000000000aa43059 14. ? @ 0x00007f35aab92ac3 15. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:54:26.286074 [ 2688 ] {ad986ab4-d5d9-4a33-b665-8c93c58f87b5} TCPHandler: Code: 439. DB::Exception: Received from 127.0.0.1:9000. DB::Exception: Cannot schedule a task: failed to start the thread (threads=1, jobs=1). Stack trace: 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af819ed 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80746 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000267fd682 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000267fd094 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:1197: ? @ 0x00000000267e6c01 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000267d95d5 10. ./build_docker/./src/Storages/ObjectStorage/StorageObjectStorage.cpp:233: DB::(anonymous namespace)::ReadFromObjectStorageStep::createIterator(DB::ActionsDAG::Node const*) @ 0x00000000267c14a8 11. ./build_docker/./src/Storages/ObjectStorage/StorageObjectStorage.cpp:172: DB::(anonymous namespace)::ReadFromObjectStorageStep::applyFilters(DB::ActionDAGNodes) @ 0x00000000267c0ef8 12. ./contrib/llvm-project/libcxx/include/vector:590: DB::SourceStepWithFilter::applyFilters() @ 0x000000002df93a35 13. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizePrimaryKeyConditionAndLimit.cpp:0: DB::QueryPlanOptimizations::optimizePrimaryKeyConditionAndLimit(std::vector> const&) @ 0x000000002df9366a 14. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:122: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x000000002df62d06 15. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:507: DB::QueryPlan::optimize(DB::QueryPlanOptimizationSettings const&) @ 0x000000002de001ca 16. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:36: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000002ddfec4b 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000002942117f 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x00000000294209e7 19. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b382fc 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 21. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 22. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 26. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 27. asan_thread_start(void*) @ 0x000000000aa43059 28. ? @ 0x00007f35aab92ac3 29. ? @ 0x00007f35aac24850 : 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. ./contrib/llvm-project/libcxx/include/string:1499: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x000000001aeb974e 3. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::Connection::receiveException() const @ 0x000000002cee6c6a 4. ./build_docker/./src/Client/Connection.cpp:0: DB::Connection::receivePacket() @ 0x000000002cef780e 5. ./build_docker/./src/Client/MultiplexedConnections.cpp:340: DB::MultiplexedConnections::receivePacketUnlocked(std::function) @ 0x000000002cf8e09e 6. ./build_docker/./src/QueryPipeline/RemoteQueryExecutorReadContext.cpp:0: DB::RemoteQueryExecutorReadContext::Task::run(std::function, std::function) @ 0x00000000278ad616 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000278ab436 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000278aaa44 9. ./contrib/boost/boost/context/fiber_ucontext.hpp:82: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x00000000278a8394 2025.09.09 14:54:26.432856 [ 3640 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 14:54:26.771597 [ 3143 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:54:26.831156 [ 3142 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:54:27.451396 [ 3640 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 14:54:27.773791 [ 3157 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:54:27.833367 [ 3161 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:54:28.446743 [ 2686 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 14:54:28.776053 [ 3164 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:54:28.835608 [ 3179 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:54:29.470670 [ 2686 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 14:54:29.778394 [ 3196 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:54:29.840364 [ 3199 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:54:30.478673 [ 3766 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 14:54:30.780605 [ 3217 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:54:30.842540 [ 3218 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:54:30.911264 [ 2686 ] {464ea319-1ea8-4aea-adbc-ba020d26cdbe} executeQuery: Code: 16. DB::Exception: There is no column with name `alias` in table test_3.full_duplicates (d2e017e0-e7af-4afd-94b8-5b458ce29494). There are columns: pk, sk, val, partition_key, mat. (NO_SUCH_COLUMN_IN_TABLE) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:58656) (comment: 01581_deduplicate_by_columns_local.sql) (in query: -- ERROR cases OPTIMIZE TABLE full_duplicates DEDUPLICATE BY pk, sk, val, mat, alias;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&) @ 0x00000000286dd420 4. ./build_docker/./src/Storages/StorageSnapshot.cpp:281: DB::StorageSnapshot::check(std::vector> const&) const @ 0x000000002bd5ad66 5. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:0: DB::InterpreterOptimizeQuery::execute() @ 0x0000000029bdac80 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b382fc 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 9. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 13. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 14. asan_thread_start(void*) @ 0x000000000aa43059 15. ? @ 0x00007f35aab92ac3 16. ? @ 0x00007f35aac24850 2025.09.09 14:54:30.916918 [ 2686 ] {464ea319-1ea8-4aea-adbc-ba020d26cdbe} TCPHandler: Code: 16. DB::Exception: There is no column with name `alias` in table test_3.full_duplicates (d2e017e0-e7af-4afd-94b8-5b458ce29494). There are columns: pk, sk, val, partition_key, mat. (NO_SUCH_COLUMN_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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&) @ 0x00000000286dd420 4. ./build_docker/./src/Storages/StorageSnapshot.cpp:281: DB::StorageSnapshot::check(std::vector> const&) const @ 0x000000002bd5ad66 5. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:0: DB::InterpreterOptimizeQuery::execute() @ 0x0000000029bdac80 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b382fc 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 9. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 13. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 14. asan_thread_start(void*) @ 0x000000000aa43059 15. ? @ 0x00007f35aab92ac3 16. ? @ 0x00007f35aac24850 2025.09.09 14:54:30.987042 [ 2686 ] {b481f656-1b3b-44a2-bde5-aaa8636ff8e5} executeQuery: Code: 8. DB::Exception: DEDUPLICATE BY expression must include all columns used in table's ORDER BY, PRIMARY KEY, or PARTITION BY but 'pk' is missing. Expanded DEDUPLICATE BY columns expression: ['sk', 'val']. (THERE_IS_NO_COLUMN) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:58656) (comment: 01581_deduplicate_by_columns_local.sql) (in query: OPTIMIZE TABLE full_duplicates DEDUPLICATE BY sk, val;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception, std::__wrap_iter, char>>(int, FormatStringHelperImpl::type, std::type_identity, std::__wrap_iter, char>>::type>, String const&, fmt::v9::join_view, std::__wrap_iter, char>&&) @ 0x0000000029bdca7a 4. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:73: DB::InterpreterOptimizeQuery::execute() @ 0x0000000029bdba2e 5. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b382fc 6. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 8. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 12. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 13. asan_thread_start(void*) @ 0x000000000aa43059 14. ? @ 0x00007f35aab92ac3 15. ? @ 0x00007f35aac24850 2025.09.09 14:54:30.989546 [ 2686 ] {b481f656-1b3b-44a2-bde5-aaa8636ff8e5} TCPHandler: Code: 8. DB::Exception: DEDUPLICATE BY expression must include all columns used in table's ORDER BY, PRIMARY KEY, or PARTITION BY but 'pk' is missing. Expanded DEDUPLICATE BY columns expression: ['sk', 'val']. (THERE_IS_NO_COLUMN), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception, std::__wrap_iter, char>>(int, FormatStringHelperImpl::type, std::type_identity, std::__wrap_iter, char>>::type>, String const&, fmt::v9::join_view, std::__wrap_iter, char>&&) @ 0x0000000029bdca7a 4. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:73: DB::InterpreterOptimizeQuery::execute() @ 0x0000000029bdba2e 5. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b382fc 6. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 8. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 12. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 13. asan_thread_start(void*) @ 0x000000000aa43059 14. ? @ 0x00007f35aab92ac3 15. ? @ 0x00007f35aac24850 2025.09.09 14:54:31.133084 [ 2686 ] {52a2b6b9-7a6f-4ea7-b062-464ac6a42c04} executeQuery: Code: 51. DB::Exception: Empty list of columns queried. There are columns: pk, sk, val, partition_key, mat. (EMPTY_LIST_OF_COLUMNS_QUERIED) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:58656) (comment: 01581_deduplicate_by_columns_local.sql) (in query: OPTIMIZE TABLE full_duplicates DEDUPLICATE BY * EXCEPT(pk, sk, val, mat, alias, partition_key);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x000000000aafc574 4. ./build_docker/./src/Storages/StorageSnapshot.cpp:265: DB::StorageSnapshot::check(std::vector> const&) const @ 0x000000002bd5ae5e 5. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:0: DB::InterpreterOptimizeQuery::execute() @ 0x0000000029bdac80 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b382fc 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 9. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 13. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 14. asan_thread_start(void*) @ 0x000000000aa43059 15. ? @ 0x00007f35aab92ac3 16. ? @ 0x00007f35aac24850 2025.09.09 14:54:31.137711 [ 2686 ] {52a2b6b9-7a6f-4ea7-b062-464ac6a42c04} TCPHandler: Code: 51. DB::Exception: Empty list of columns queried. There are columns: pk, sk, val, partition_key, mat. (EMPTY_LIST_OF_COLUMNS_QUERIED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x000000000aafc574 4. ./build_docker/./src/Storages/StorageSnapshot.cpp:265: DB::StorageSnapshot::check(std::vector> const&) const @ 0x000000002bd5ae5e 5. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:0: DB::InterpreterOptimizeQuery::execute() @ 0x0000000029bdac80 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b382fc 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 9. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 13. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 14. asan_thread_start(void*) @ 0x000000000aa43059 15. ? @ 0x00007f35aab92ac3 16. ? @ 0x00007f35aac24850 2025.09.09 14:54:31.232326 [ 2686 ] {97ed6fd7-fdde-4911-97ee-04f8521c796b} executeQuery: Code: 8. DB::Exception: DEDUPLICATE BY expression must include all columns used in table's ORDER BY, PRIMARY KEY, or PARTITION BY but 'pk' is missing. Expanded DEDUPLICATE BY columns expression: ['sk', 'val', 'partition_key']. (THERE_IS_NO_COLUMN) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:58656) (comment: 01581_deduplicate_by_columns_local.sql) (in query: OPTIMIZE TABLE full_duplicates DEDUPLICATE BY * EXCEPT(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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception, std::__wrap_iter, char>>(int, FormatStringHelperImpl::type, std::type_identity, std::__wrap_iter, char>>::type>, String const&, fmt::v9::join_view, std::__wrap_iter, char>&&) @ 0x0000000029bdca7a 4. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:73: DB::InterpreterOptimizeQuery::execute() @ 0x0000000029bdba2e 5. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b382fc 6. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 8. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 12. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 13. asan_thread_start(void*) @ 0x000000000aa43059 14. ? @ 0x00007f35aab92ac3 15. ? @ 0x00007f35aac24850 2025.09.09 14:54:31.240619 [ 2686 ] {97ed6fd7-fdde-4911-97ee-04f8521c796b} TCPHandler: Code: 8. DB::Exception: DEDUPLICATE BY expression must include all columns used in table's ORDER BY, PRIMARY KEY, or PARTITION BY but 'pk' is missing. Expanded DEDUPLICATE BY columns expression: ['sk', 'val', 'partition_key']. (THERE_IS_NO_COLUMN), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception, std::__wrap_iter, char>>(int, FormatStringHelperImpl::type, std::type_identity, std::__wrap_iter, char>>::type>, String const&, fmt::v9::join_view, std::__wrap_iter, char>&&) @ 0x0000000029bdca7a 4. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:73: DB::InterpreterOptimizeQuery::execute() @ 0x0000000029bdba2e 5. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b382fc 6. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 8. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 12. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 13. asan_thread_start(void*) @ 0x000000000aa43059 14. ? @ 0x00007f35aab92ac3 15. ? @ 0x00007f35aac24850 2025.09.09 14:54:31.317741 [ 2686 ] {fb7b27f6-9d54-450b-bc63-054d401b2d0f} executeQuery: Code: 8. DB::Exception: DEDUPLICATE BY expression must include all columns used in table's ORDER BY, PRIMARY KEY, or PARTITION BY but 'sk' is missing. Expanded DEDUPLICATE BY columns expression: ['pk', 'val', 'partition_key']. (THERE_IS_NO_COLUMN) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:58656) (comment: 01581_deduplicate_by_columns_local.sql) (in query: OPTIMIZE TABLE full_duplicates DEDUPLICATE BY * EXCEPT(sk);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception, std::__wrap_iter, char>>(int, FormatStringHelperImpl::type, std::type_identity, std::__wrap_iter, char>>::type>, String const&, fmt::v9::join_view, std::__wrap_iter, char>&&) @ 0x0000000029bdca7a 4. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:73: DB::InterpreterOptimizeQuery::execute() @ 0x0000000029bdba2e 5. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b382fc 6. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 8. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 12. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 13. asan_thread_start(void*) @ 0x000000000aa43059 14. ? @ 0x00007f35aab92ac3 15. ? @ 0x00007f35aac24850 2025.09.09 14:54:31.322467 [ 2686 ] {fb7b27f6-9d54-450b-bc63-054d401b2d0f} TCPHandler: Code: 8. DB::Exception: DEDUPLICATE BY expression must include all columns used in table's ORDER BY, PRIMARY KEY, or PARTITION BY but 'sk' is missing. Expanded DEDUPLICATE BY columns expression: ['pk', 'val', 'partition_key']. (THERE_IS_NO_COLUMN), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception, std::__wrap_iter, char>>(int, FormatStringHelperImpl::type, std::type_identity, std::__wrap_iter, char>>::type>, String const&, fmt::v9::join_view, std::__wrap_iter, char>&&) @ 0x0000000029bdca7a 4. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:73: DB::InterpreterOptimizeQuery::execute() @ 0x0000000029bdba2e 5. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b382fc 6. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 8. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 12. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 13. asan_thread_start(void*) @ 0x000000000aa43059 14. ? @ 0x00007f35aab92ac3 15. ? @ 0x00007f35aac24850 2025.09.09 14:54:31.421757 [ 2686 ] {1b3260c4-e281-4b94-90af-4dccdb2d1df4} executeQuery: Code: 8. DB::Exception: DEDUPLICATE BY expression must include all columns used in table's ORDER BY, PRIMARY KEY, or PARTITION BY but 'partition_key' is missing. Expanded DEDUPLICATE BY columns expression: ['pk', 'sk', 'val']. (THERE_IS_NO_COLUMN) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:58656) (comment: 01581_deduplicate_by_columns_local.sql) (in query: OPTIMIZE TABLE full_duplicates DEDUPLICATE BY * EXCEPT(partition_key);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception, std::__wrap_iter, char>>(int, FormatStringHelperImpl::type, std::type_identity, std::__wrap_iter, char>>::type>, String const&, fmt::v9::join_view, std::__wrap_iter, char>&&) @ 0x0000000029bdca7a 4. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:73: DB::InterpreterOptimizeQuery::execute() @ 0x0000000029bdba2e 5. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b382fc 6. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 8. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 12. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 13. asan_thread_start(void*) @ 0x000000000aa43059 14. ? @ 0x00007f35aab92ac3 15. ? @ 0x00007f35aac24850 2025.09.09 14:54:31.428566 [ 2686 ] {1b3260c4-e281-4b94-90af-4dccdb2d1df4} TCPHandler: Code: 8. DB::Exception: DEDUPLICATE BY expression must include all columns used in table's ORDER BY, PRIMARY KEY, or PARTITION BY but 'partition_key' is missing. Expanded DEDUPLICATE BY columns expression: ['pk', 'sk', 'val']. (THERE_IS_NO_COLUMN), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception, std::__wrap_iter, char>>(int, FormatStringHelperImpl::type, std::type_identity, std::__wrap_iter, char>>::type>, String const&, fmt::v9::join_view, std::__wrap_iter, char>&&) @ 0x0000000029bdca7a 4. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:73: DB::InterpreterOptimizeQuery::execute() @ 0x0000000029bdba2e 5. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b382fc 6. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 8. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 12. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 13. asan_thread_start(void*) @ 0x000000000aa43059 14. ? @ 0x00007f35aab92ac3 15. ? @ 0x00007f35aac24850 2025.09.09 14:54:31.479379 [ 3766 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 14:54:31.576981 [ 3330 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {120a6b4f-0f93-4c7b-b7cc-46807ffa23fa::202509_1_40_8}: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=13, 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af80b71 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80746 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002c765aab 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:1197: ? @ 0x000000002c7602b8 8. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x000000002c75fc2b 9. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:0: DB::MergeTreeReaderCompact::MergeTreeReaderCompact(std::shared_ptr, DB::NamesAndTypesList, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*, DB::MarkCache*, DB::MarkRanges, DB::MergeTreeReaderSettings, std::map, std::allocator>>, std::function const&, int) @ 0x000000002c7aee03 10. ./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.h:16: DB::MergeTreeReaderCompactSingleBuffer::MergeTreeReaderCompactSingleBuffer&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int&&) @ 0x000000002c5d6d21 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::MergeTreeDataPartCompact::getReader(DB::NamesAndTypesList const&, std::shared_ptr const&, DB::MarkRanges const&, std::unordered_map, std::equal_to, std::allocator>> const&, DB::UncompressedCache*, DB::MarkCache*, std::shared_ptr const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) const @ 0x000000002c5d1037 12. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:169: DB::MergeTreeSequentialSource::MergeTreeSequentialSource(DB::MergeTreeSequentialSourceType, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::vector>, std::optional, bool, bool, bool) @ 0x000000002c80c330 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:35: DB::MergeTreeSequentialSource* std::construct_at[abi:v15007] const&, std::shared_ptr&, std::shared_ptr&, std::vector>&, std::optional, bool, bool&, bool&, DB::MergeTreeSequentialSource*>(DB::MergeTreeSequentialSource*, DB::MergeTreeSequentialSourceType&, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr&, std::shared_ptr&, std::vector>&, std::optional&&, bool&&, bool&, bool&) @ 0x000000002c81320f 14. ./contrib/llvm-project/libcxx/include/__memory/allocator_traits.h:298: DB::createMergeTreeSequentialSource(DB::MergeTreeSequentialSourceType, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::vector>, std::optional, std::shared_ptr>, bool, bool, bool) @ 0x000000002c810812 15. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1136: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::createMergedStream() @ 0x000000002c3dd079 16. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() @ 0x000000002c3d6516 17. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:534: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x000000002c3e2799 18. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::execute() @ 0x000000002c3ef3fe 19. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:0: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000002cc2f4c0 20. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000002c427f28 21. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000002c429675 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7eaf0 23. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001af8a79f 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 26. asan_thread_start(void*) @ 0x000000000aa43059 27. ? @ 0x00007f35aab92ac3 28. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:54:31.613600 [ 3334 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {108b9aab-fe65-4ab9-8855-f1d393dc8a98::202509_1_21_4}: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=13, jobs=2). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af80b71 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80746 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002c765aab 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:1197: ? @ 0x000000002c7602b8 8. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x000000002c75fc2b 9. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:0: DB::MergeTreeReaderCompact::MergeTreeReaderCompact(std::shared_ptr, DB::NamesAndTypesList, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*, DB::MarkCache*, DB::MarkRanges, DB::MergeTreeReaderSettings, std::map, std::allocator>>, std::function const&, int) @ 0x000000002c7aee03 10. ./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.h:16: DB::MergeTreeReaderCompactSingleBuffer::MergeTreeReaderCompactSingleBuffer&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int&&) @ 0x000000002c5d6d21 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::MergeTreeDataPartCompact::getReader(DB::NamesAndTypesList const&, std::shared_ptr const&, DB::MarkRanges const&, std::unordered_map, std::equal_to, std::allocator>> const&, DB::UncompressedCache*, DB::MarkCache*, std::shared_ptr const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) const @ 0x000000002c5d1037 12. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:169: DB::MergeTreeSequentialSource::MergeTreeSequentialSource(DB::MergeTreeSequentialSourceType, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::vector>, std::optional, bool, bool, bool) @ 0x000000002c80c330 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:35: DB::MergeTreeSequentialSource* std::construct_at[abi:v15007] const&, std::shared_ptr&, std::shared_ptr&, std::vector>&, std::optional, bool, bool&, bool&, DB::MergeTreeSequentialSource*>(DB::MergeTreeSequentialSource*, DB::MergeTreeSequentialSourceType&, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr&, std::shared_ptr&, std::vector>&, std::optional&&, bool&&, bool&, bool&) @ 0x000000002c81320f 14. ./contrib/llvm-project/libcxx/include/__memory/allocator_traits.h:298: DB::createMergeTreeSequentialSource(DB::MergeTreeSequentialSourceType, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::vector>, std::optional, std::shared_ptr>, bool, bool, bool) @ 0x000000002c810812 15. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1136: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::createMergedStream() @ 0x000000002c3dd079 16. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() @ 0x000000002c3d6516 17. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:534: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x000000002c3e2799 18. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::execute() @ 0x000000002c3ef3fe 19. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:0: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000002cc2f4c0 20. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000002c427f28 21. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000002c429675 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7eaf0 23. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001af8a79f 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 26. asan_thread_start(void*) @ 0x000000000aa43059 27. ? @ 0x00007f35aab92ac3 28. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:54:31.782603 [ 2736 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:54:31.844618 [ 2756 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:54:32.516162 [ 3604 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 14:54:32.785135 [ 2769 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:54:32.846631 [ 2778 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:54:33.533868 [ 4017 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 14:54:33.787155 [ 2798 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:54:33.848863 [ 2805 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:54:34.539881 [ 4017 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 14:54:34.789326 [ 2840 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:54:34.855167 [ 2833 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:54:35.557968 [ 2688 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 14:54:35.795802 [ 2861 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:54:35.856983 [ 2864 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:54:36.592192 [ 2688 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 14:54:36.797882 [ 2892 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:54:36.859265 [ 2890 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:54:37.606035 [ 2688 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 14:54:37.799986 [ 2921 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:54:37.861814 [ 2902 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:54:38.004811 [ 4017 ] {23049ccd-86d1-430b-b404-3816528e2fce} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=773, jobs=733). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:52164) (comment: 01581_deduplicate_by_columns_local.sql) (in query: SELECT `__table1`.`pk` AS `pk`, `__table1`.`sk` AS `sk`, `__table1`.`val` AS `val`, `__table1`.`partition_key` AS `partition_key` FROM `test_3`.`source_data` AS `__table1`), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af872f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af7b2d1 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af7c3f3 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d36920d 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000002d369e5f 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processOrdinaryQuery() @ 0x000000002d18af7b 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d17644a 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 15. asan_thread_start(void*) @ 0x000000000aa43059 16. ? @ 0x00007f35aab92ac3 17. ? @ 0x00007f35aac24850 2025.09.09 14:54:38.006392 [ 4017 ] {23049ccd-86d1-430b-b404-3816528e2fce} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=773, 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af872f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af7b2d1 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af7c3f3 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d36920d 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000002d369e5f 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processOrdinaryQuery() @ 0x000000002d18af7b 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d17644a 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 15. asan_thread_start(void*) @ 0x000000000aa43059 16. ? @ 0x00007f35aab92ac3 17. ? @ 0x00007f35aac24850 2025.09.09 14:54:38.060653 [ 2686 ] {fa55a584-eb5a-4f96-aec1-a94b9081781f} executeQuery: Code: 439. DB::Exception: Received from 127.0.0.5:9000. DB::Exception: Cannot schedule a task: fault injected (threads=773, jobs=733). Stack trace: 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af872f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af7b2d1 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af7c3f3 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d36920d 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000002d369e5f 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processOrdinaryQuery() @ 0x000000002d18af7b 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d17644a 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 15. asan_thread_start(void*) @ 0x000000000aa43059 16. ? @ 0x00007f35aab92ac3 17. ? @ 0x00007f35aac24850 : While executing Remote. (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:58656) (comment: 01581_deduplicate_by_columns_local.sql) (in query: INSERT INTO partial_duplicates SELECT * FROM source_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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. ./contrib/llvm-project/libcxx/include/string:1499: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x000000001aeb974e 3. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::Connection::receiveException() const @ 0x000000002cee6c6a 4. ./build_docker/./src/Client/Connection.cpp:0: DB::Connection::receivePacket() @ 0x000000002cef780e 5. ./build_docker/./src/Client/MultiplexedConnections.cpp:340: DB::MultiplexedConnections::receivePacketUnlocked(std::function) @ 0x000000002cf8e09e 6. ./build_docker/./src/QueryPipeline/RemoteQueryExecutorReadContext.cpp:0: DB::RemoteQueryExecutorReadContext::Task::run(std::function, std::function) @ 0x00000000278ad616 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000278ab436 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000278aaa44 9. ./contrib/boost/boost/context/fiber_ucontext.hpp:82: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x00000000278a8394 2025.09.09 14:54:38.069299 [ 2686 ] {fa55a584-eb5a-4f96-aec1-a94b9081781f} TCPHandler: Code: 439. DB::Exception: Received from 127.0.0.5:9000. DB::Exception: Cannot schedule a task: fault injected (threads=773, jobs=733). Stack trace: 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af872f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af7b2d1 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af7c3f3 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d36920d 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000002d369e5f 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processOrdinaryQuery() @ 0x000000002d18af7b 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d17644a 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 15. asan_thread_start(void*) @ 0x000000000aa43059 16. ? @ 0x00007f35aab92ac3 17. ? @ 0x00007f35aac24850 : 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. ./contrib/llvm-project/libcxx/include/string:1499: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x000000001aeb974e 3. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::Connection::receiveException() const @ 0x000000002cee6c6a 4. ./build_docker/./src/Client/Connection.cpp:0: DB::Connection::receivePacket() @ 0x000000002cef780e 5. ./build_docker/./src/Client/MultiplexedConnections.cpp:340: DB::MultiplexedConnections::receivePacketUnlocked(std::function) @ 0x000000002cf8e09e 6. ./build_docker/./src/QueryPipeline/RemoteQueryExecutorReadContext.cpp:0: DB::RemoteQueryExecutorReadContext::Task::run(std::function, std::function) @ 0x00000000278ad616 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000278ab436 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000278aaa44 9. ./contrib/boost/boost/context/fiber_ucontext.hpp:82: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x00000000278a8394 2025.09.09 14:54:38.069452 [ 4023 ] {662ec472-933f-41b3-a1c1-de5627d78c2d} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=773, jobs=732). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:58434) (comment: 01581_deduplicate_by_columns_local.sql) (in query: SELECT `__table1`.`pk` AS `pk`, `__table1`.`sk` AS `sk`, `__table1`.`val` AS `val`, `__table1`.`partition_key` AS `partition_key` FROM `test_3`.`source_data` AS `__table1`), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af872f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af7b2d1 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af7c3f3 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d36920d 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000002d369e5f 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processOrdinaryQuery() @ 0x000000002d18af7b 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d17644a 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 15. asan_thread_start(void*) @ 0x000000000aa43059 16. ? @ 0x00007f35aab92ac3 17. ? @ 0x00007f35aac24850 2025.09.09 14:54:38.093569 [ 4023 ] {662ec472-933f-41b3-a1c1-de5627d78c2d} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=773, jobs=732). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af872f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af7b2d1 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af7c3f3 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d36920d 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000002d369e5f 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processOrdinaryQuery() @ 0x000000002d18af7b 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d17644a 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 15. asan_thread_start(void*) @ 0x000000000aa43059 16. ? @ 0x00007f35aab92ac3 17. ? @ 0x00007f35aac24850 2025.09.09 14:54:38.096932 [ 4023 ] {662ec472-933f-41b3-a1c1-de5627d78c2d} TCPHandler: Client has gone away. 2025.09.09 14:54:38.550642 [ 2686 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 14:54:38.815036 [ 2943 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:54:38.863981 [ 2945 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:54:39.654859 [ 4017 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 14:54:39.817396 [ 2979 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:54:39.866393 [ 2981 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:54:40.447751 [ 2686 ] {7d6a3846-81d1-4949-b5c3-00bebc2be584} executeQuery: Code: 57. DB::Exception: Table test_3.t_vertical_merges already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:33410) (comment: 02286_vertical_merges_missed_column.sql) (in query: CREATE TABLE t_vertical_merges (`a` Array(Int16), `b` Int8) ENGINE = MergeTree ORDER BY tuple() SETTINGS vertical_merge_algorithm_min_columns_to_activate = 1, vertical_merge_algorithm_min_rows_to_activate = 1, min_bytes_for_wide_part = 0, index_granularity = 7028, 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 = 531917851, compact_parts_max_granules_to_buffer = 231, compact_parts_merge_max_bytes_to_prefetch_part = 24720855, merge_max_block_size = 17180, old_parts_lifetime = 10., prefer_fetch_merged_part_size_threshold = 4541652606, min_merge_bytes_to_use_direct_io = 2554877212, index_granularity_bytes = 22945393, concurrent_part_removal_threshold = 52, allow_vertical_merges_from_compact_to_wide_parts = false, cache_populated_by_fetch = false, marks_compress_block_size = 18067, primary_key_compress_block_size = 15941), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa91e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1558: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291bc5ff 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291ac835 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000291c3415 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b382fc 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 15. asan_thread_start(void*) @ 0x000000000aa43059 16. ? @ 0x00007f35aab92ac3 17. ? @ 0x00007f35aac24850 2025.09.09 14:54:40.455510 [ 2686 ] {7d6a3846-81d1-4949-b5c3-00bebc2be584} TCPHandler: Code: 57. DB::Exception: Table test_3.t_vertical_merges already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa91e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1558: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291bc5ff 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291ac835 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000291c3415 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b382fc 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 15. asan_thread_start(void*) @ 0x000000000aa43059 16. ? @ 0x00007f35aab92ac3 17. ? @ 0x00007f35aac24850 2025.09.09 14:54:40.703455 [ 2686 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 14:54:40.820168 [ 3009 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:54:40.868587 [ 3012 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:54:41.773151 [ 2686 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 14:54:41.822602 [ 3039 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:54:41.874727 [ 3041 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:54:42.790217 [ 4017 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 14:54:42.824823 [ 3061 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:54:42.878140 [ 3059 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:54:43.128421 [ 2686 ] {3ac5a3dd-3575-4874-9485-56fa3af205d6} executeQuery: Code: 62. DB::Exception: Syntax error: failed at position 8 ('$'): $$ab . Expected one of: ALL, DISTINCT ON, DISTINCT, TOP, not empty list of expressions, list of expressions, list of elements, expression with optional alias, element of expression with optional alias, lambda expression, CAST operator, NOT, INTERVAL, CASE, DATE, TIMESTAMP, tuple, collection of literals, array, number, literal, NULL, NULL, Bool, TRUE, FALSE, string literal, asterisk, qualified asterisk, compound identifier, identifier, COLUMNS matcher, COLUMNS, qualified COLUMNS matcher, function name, substitution, MySQL-style global variable. (SYNTAX_ERROR) (version 24.8.14.10505.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:52392) (comment: 01949_heredoc_unfinished.sh) (in query: SELECT $$ab ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::createDeprecated(String const&, int, bool) @ 0x000000000aaee710 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) @ 0x000000002e9e8d35 4. ./build_docker/./src/Parsers/parseQuery.cpp:420: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x000000002e9e8e45 5. ./build_docker/./src/Interpreters/executeQuery.cpp:784: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3318a 6. ./build_docker/./src/Interpreters/executeQuery.cpp:1529: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000029b3ed3f 7. ./build_docker/./src/Server/HTTPHandler.cpp:529: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000002d0662d1 8. ./build_docker/./src/Server/HTTPHandler.cpp:705: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000002d06d139 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000002d1cc337 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 13. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 14. asan_thread_start(void*) @ 0x000000000aa43059 15. ? @ 0x00007f35aab92ac3 16. ? @ 0x00007f35aac24850 2025.09.09 14:54:43.131921 [ 2686 ] {3ac5a3dd-3575-4874-9485-56fa3af205d6} DynamicQueryHandler: Code: 62. DB::Exception: Syntax error: failed at position 8 ('$'): $$ab . Expected one of: ALL, DISTINCT ON, DISTINCT, TOP, not empty list of expressions, list of expressions, list of elements, expression with optional alias, element of expression with optional alias, lambda expression, CAST operator, NOT, INTERVAL, CASE, DATE, TIMESTAMP, tuple, collection of literals, array, number, literal, NULL, NULL, Bool, TRUE, FALSE, string literal, asterisk, qualified asterisk, compound identifier, identifier, COLUMNS matcher, COLUMNS, qualified COLUMNS matcher, function name, substitution, MySQL-style global variable. (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::createDeprecated(String const&, int, bool) @ 0x000000000aaee710 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) @ 0x000000002e9e8d35 4. ./build_docker/./src/Parsers/parseQuery.cpp:420: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x000000002e9e8e45 5. ./build_docker/./src/Interpreters/executeQuery.cpp:784: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3318a 6. ./build_docker/./src/Interpreters/executeQuery.cpp:1529: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000029b3ed3f 7. ./build_docker/./src/Server/HTTPHandler.cpp:529: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000002d0662d1 8. ./build_docker/./src/Server/HTTPHandler.cpp:705: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000002d06d139 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000002d1cc337 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 13. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 14. asan_thread_start(void*) @ 0x000000000aa43059 15. ? @ 0x00007f35aab92ac3 16. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:54:43.264877 [ 4017 ] {d9521591-0621-4bba-877e-bbde538082fe} executeQuery: Code: 62. DB::Exception: Syntax error: failed at position 8 ('$'): $$ . Expected one of: ALL, DISTINCT ON, DISTINCT, TOP, not empty list of expressions, list of expressions, list of elements, expression with optional alias, element of expression with optional alias, lambda expression, CAST operator, NOT, INTERVAL, CASE, DATE, TIMESTAMP, tuple, collection of literals, array, number, literal, NULL, NULL, Bool, TRUE, FALSE, string literal, asterisk, qualified asterisk, compound identifier, identifier, COLUMNS matcher, COLUMNS, qualified COLUMNS matcher, function name, substitution, MySQL-style global variable. (SYNTAX_ERROR) (version 24.8.14.10505.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:52406) (comment: 01949_heredoc_unfinished.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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::createDeprecated(String const&, int, bool) @ 0x000000000aaee710 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) @ 0x000000002e9e8d35 4. ./build_docker/./src/Parsers/parseQuery.cpp:420: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x000000002e9e8e45 5. ./build_docker/./src/Interpreters/executeQuery.cpp:784: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3318a 6. ./build_docker/./src/Interpreters/executeQuery.cpp:1529: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000029b3ed3f 7. ./build_docker/./src/Server/HTTPHandler.cpp:529: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000002d0662d1 8. ./build_docker/./src/Server/HTTPHandler.cpp:705: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000002d06d139 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000002d1cc337 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 13. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 14. asan_thread_start(void*) @ 0x000000000aa43059 15. ? @ 0x00007f35aab92ac3 16. ? @ 0x00007f35aac24850 2025.09.09 14:54:43.267185 [ 4017 ] {d9521591-0621-4bba-877e-bbde538082fe} DynamicQueryHandler: Code: 62. DB::Exception: Syntax error: failed at position 8 ('$'): $$ . Expected one of: ALL, DISTINCT ON, DISTINCT, TOP, not empty list of expressions, list of expressions, list of elements, expression with optional alias, element of expression with optional alias, lambda expression, CAST operator, NOT, INTERVAL, CASE, DATE, TIMESTAMP, tuple, collection of literals, array, number, literal, NULL, NULL, Bool, TRUE, FALSE, string literal, asterisk, qualified asterisk, compound identifier, identifier, COLUMNS matcher, COLUMNS, qualified COLUMNS matcher, function name, substitution, MySQL-style global variable. (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::createDeprecated(String const&, int, bool) @ 0x000000000aaee710 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) @ 0x000000002e9e8d35 4. ./build_docker/./src/Parsers/parseQuery.cpp:420: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x000000002e9e8e45 5. ./build_docker/./src/Interpreters/executeQuery.cpp:784: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3318a 6. ./build_docker/./src/Interpreters/executeQuery.cpp:1529: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000029b3ed3f 7. ./build_docker/./src/Server/HTTPHandler.cpp:529: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000002d0662d1 8. ./build_docker/./src/Server/HTTPHandler.cpp:705: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000002d06d139 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000002d1cc337 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 13. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 14. asan_thread_start(void*) @ 0x000000000aa43059 15. ? @ 0x00007f35aab92ac3 16. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:54:43.369142 [ 4017 ] {00212592-78a7-4cd8-b7e4-f51ff2b53b6a} executeQuery: Code: 62. DB::Exception: Syntax error: failed at position 8 ('$'): $ . Expected one of: ALL, DISTINCT ON, DISTINCT, TOP, not empty list of expressions, list of expressions, list of elements, expression with optional alias, element of expression with optional alias, lambda expression, CAST operator, NOT, INTERVAL, CASE, DATE, TIMESTAMP, tuple, collection of literals, array, number, literal, NULL, NULL, Bool, TRUE, FALSE, string literal, asterisk, qualified asterisk, compound identifier, identifier, COLUMNS matcher, COLUMNS, qualified COLUMNS matcher, function name, substitution, MySQL-style global variable. (SYNTAX_ERROR) (version 24.8.14.10505.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:52412) (comment: 01949_heredoc_unfinished.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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::createDeprecated(String const&, int, bool) @ 0x000000000aaee710 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) @ 0x000000002e9e8d35 4. ./build_docker/./src/Parsers/parseQuery.cpp:420: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x000000002e9e8e45 5. ./build_docker/./src/Interpreters/executeQuery.cpp:784: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3318a 6. ./build_docker/./src/Interpreters/executeQuery.cpp:1529: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000029b3ed3f 7. ./build_docker/./src/Server/HTTPHandler.cpp:529: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000002d0662d1 8. ./build_docker/./src/Server/HTTPHandler.cpp:705: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000002d06d139 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000002d1cc337 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 13. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 14. asan_thread_start(void*) @ 0x000000000aa43059 15. ? @ 0x00007f35aab92ac3 16. ? @ 0x00007f35aac24850 2025.09.09 14:54:43.372028 [ 4017 ] {00212592-78a7-4cd8-b7e4-f51ff2b53b6a} DynamicQueryHandler: Code: 62. DB::Exception: Syntax error: failed at position 8 ('$'): $ . Expected one of: ALL, DISTINCT ON, DISTINCT, TOP, not empty list of expressions, list of expressions, list of elements, expression with optional alias, element of expression with optional alias, lambda expression, CAST operator, NOT, INTERVAL, CASE, DATE, TIMESTAMP, tuple, collection of literals, array, number, literal, NULL, NULL, Bool, TRUE, FALSE, string literal, asterisk, qualified asterisk, compound identifier, identifier, COLUMNS matcher, COLUMNS, qualified COLUMNS matcher, function name, substitution, MySQL-style global variable. (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::createDeprecated(String const&, int, bool) @ 0x000000000aaee710 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) @ 0x000000002e9e8d35 4. ./build_docker/./src/Parsers/parseQuery.cpp:420: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x000000002e9e8e45 5. ./build_docker/./src/Interpreters/executeQuery.cpp:784: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3318a 6. ./build_docker/./src/Interpreters/executeQuery.cpp:1529: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000029b3ed3f 7. ./build_docker/./src/Server/HTTPHandler.cpp:529: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000002d0662d1 8. ./build_docker/./src/Server/HTTPHandler.cpp:705: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000002d06d139 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000002d1cc337 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 13. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 14. asan_thread_start(void*) @ 0x000000000aa43059 15. ? @ 0x00007f35aab92ac3 16. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:54:43.817544 [ 2686 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 14:54:43.827192 [ 3082 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:54:43.880147 [ 3085 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:54:44.806991 [ 2688 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 14:54:44.830116 [ 3106 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:54:44.882544 [ 3110 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:54:44.908123 [ 2686 ] {a5e590b7-5408-46ab-876e-9802994edc20} executeQuery: Code: 53. DB::Exception: Function dictGetString dictionary attribute has different type Nullable(String) expected String: In scope SELECT dictGetString('02125_test_dictionary', 'value', toUInt64(0)). (TYPE_MISMATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:33466) (comment: 02125_dict_get_type_nullable_fix.sql) (in query: SELECT dictGetString('02125_test_dictionary', 'value', toUInt64(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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000ac6ad20 4. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b611a1e 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aa8c635 6. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aac91d5 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000cccccfb 8. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000cccc1ab 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccccc2a 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccce65c 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd2030 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002839a3af 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000028367bce 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028366290 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283b62c9 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002835ae03 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000028359104 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000028357f0d 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002921bdcc 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&) @ 0x000000002941f313 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&) @ 0x0000000029419aef 22. ./contrib/llvm-project/libcxx/include/vector:432: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000029421f5d 23. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000029344c1b 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*) @ 0x0000000029b3703b 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 27. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 31. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 2025.09.09 14:54:44.911566 [ 2686 ] {a5e590b7-5408-46ab-876e-9802994edc20} TCPHandler: Code: 53. DB::Exception: Function dictGetString dictionary attribute has different type Nullable(String) expected String: In scope SELECT dictGetString('02125_test_dictionary', 'value', toUInt64(0)). (TYPE_MISMATCH), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000ac6ad20 4. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b611a1e 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aa8c635 6. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aac91d5 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000cccccfb 8. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000cccc1ab 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccccc2a 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccce65c 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd2030 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002839a3af 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000028367bce 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028366290 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283b62c9 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002835ae03 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000028359104 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000028357f0d 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002921bdcc 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&) @ 0x000000002941f313 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&) @ 0x0000000029419aef 22. ./contrib/llvm-project/libcxx/include/vector:432: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000029421f5d 23. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000029344c1b 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*) @ 0x0000000029b3703b 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 27. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 31. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 2025.09.09 14:54:45.832078 [ 3130 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:54:45.863292 [ 2688 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 14:54:45.884643 [ 3136 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:54:45.954792 [ 2686 ] {77467a85-f64c-46d0-9f6f-3acdb9fae10e} virtual DB::ConcurrentHashJoin::~ConcurrentHashJoin(): Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=8, jobs=2). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af80b71 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af82f33 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000287ae4d3 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:216: DB::JoinStep::~JoinStep() @ 0x000000002ddd8c62 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: std::__list_imp>::clear() @ 0x000000002de1141e 9. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:32: DB::QueryPlan::~QueryPlan() @ 0x000000002ddfbf12 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Planner::~Planner() @ 0x00000000287a4997 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterSelectQueryAnalyzer::getSampleBlock(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000029420564 12. ./build_docker/./src/Interpreters/ClusterProxy/executeQuery.cpp:680: DB::ClusterProxy::executeQueryWithParallelReplicas(DB::QueryPlan&, DB::StorageID const&, DB::QueryProcessingStage::Enum, std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr> const>, std::unique_ptr>) @ 0x000000002aaaf096 13. ./build_docker/./src/Planner/PlannerJoinTree.cpp:996: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x000000002946e7d2 14. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1795: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000002945d99d 15. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x000000002942c986 16. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x00000000294261fb 17. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000029421552 18. ./build_docker/./src/Storages/buildQueryTreeForShard.cpp:0: DB::(anonymous namespace)::executeSubqueryNode(std::shared_ptr const&, std::shared_ptr&, unsigned long) @ 0x000000002bde604f 19. ./build_docker/./src/Storages/buildQueryTreeForShard.cpp:355: DB::buildQueryTreeForShard(std::shared_ptr const&, std::shared_ptr) @ 0x000000002bddfa63 20. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::buildQueryPlanForParallelReplicas(DB::QueryNode const&, std::shared_ptr const&, std::shared_ptr> const>) @ 0x0000000029451818 21. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x000000002942cb63 22. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x00000000294261fb 23. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000029421552 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1182: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3737e 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 27. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 31. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:54:46.696374 [ 2686 ] {77467a85-f64c-46d0-9f6f-3acdb9fae10e} virtual DB::ConcurrentHashJoin::~ConcurrentHashJoin(): Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=7, 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af80b71 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af82f33 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000287ae4d3 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:216: DB::JoiningTransform::~JoiningTransform() @ 0x000000002d9d146b 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:216: std::vector, std::allocator>>::__destroy_vector::operator()[abi:v15007]() @ 0x00000000260eaf4e 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::IQueryPlanStep::~IQueryPlanStep() @ 0x00000000260ea926 10. ./src/Processors/QueryPlan/JoinStep.h:13: DB::JoinStep::~JoinStep() @ 0x000000002ddd8c75 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: std::__list_imp>::clear() @ 0x000000002de1141e 12. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:32: DB::QueryPlan::~QueryPlan() @ 0x000000002ddfbf12 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Planner::~Planner() @ 0x00000000287a4997 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterSelectQueryAnalyzer::~InterpreterSelectQueryAnalyzer() @ 0x00000000287a3c35 15. ./build_docker/./src/Storages/buildQueryTreeForShard.cpp:0: DB::(anonymous namespace)::executeSubqueryNode(std::shared_ptr const&, std::shared_ptr&, unsigned long) @ 0x000000002bde8350 16. ./build_docker/./src/Storages/buildQueryTreeForShard.cpp:355: DB::buildQueryTreeForShard(std::shared_ptr const&, std::shared_ptr) @ 0x000000002bddfa63 17. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::buildQueryPlanForParallelReplicas(DB::QueryNode const&, std::shared_ptr const&, std::shared_ptr> const>) @ 0x0000000029451818 18. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x000000002942cb63 19. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x00000000294261fb 20. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000029421552 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1182: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3737e 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 23. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 24. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 29. asan_thread_start(void*) @ 0x000000000aa43059 30. ? @ 0x00007f35aab92ac3 31. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:54:46.719899 [ 4022 ] {c3e16843-4abf-4a94-83b9-0fc36039e9c1} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=7, jobs=2). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:47796) (comment: 02967_parallel_replicas_join_algo_and_analyzer_3.sh) (in query: SELECT `__table1`.`key` AS `key`, `__table1`.`value` AS `value` FROM `test_1`.`num_2` AS `__table1` GLOBAL ALL INNER JOIN `_data_6159103449907252772_9558241464499801717` AS `__table2` ON `__table1`.`key` = `__table2`.`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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af80b71 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80746 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d34b5ca 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000002d3486e4 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000002d34827b 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002d36bcf7 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 12. asan_thread_start(void*) @ 0x000000000aa43059 13. ? @ 0x00007f35aab92ac3 14. ? @ 0x00007f35aac24850 2025.09.09 14:54:46.793096 [ 2686 ] {77467a85-f64c-46d0-9f6f-3acdb9fae10e} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=6, jobs=0): (while reading column value): (while reading from part /var/lib/clickhouse/store/3b7/3b7f9237-6979-480e-af74-6371475b2898/all_2_2_0/ in table test_1.num_2 (3b7f9237-6979-480e-af74-6371475b2898) located on disk default of type local, from mark 2 with max_rows_to_read = 57344): While executing MergeTreeSelect(pool: ReadPoolParallelReplicas, algorithm: Thread). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:33490) (comment: 02967_parallel_replicas_join_algo_and_analyzer_3.sh) (in query: select * from (select key, value from num_1) l inner join (select key, value from num_2 inner join (select number * 7 as key from numbers(1e5)) as nn on num_2.key = nn.key settings parallel_replicas_prefer_local_join=0) r on l.key = r.key order by l.key limit 10 offset 10000 SETTINGS enable_analyzer=1, enable_parallel_replicas = 2, max_parallel_replicas = 2, parallel_replicas_for_non_replicated_merge_tree = 1, cluster_for_parallel_replicas = 'test_cluster_one_shard_three_replicas_localhost', parallel_replicas_local_plan=1, parallel_replicas_prefer_local_join=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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af80b71 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80746 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000266005a2 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000265fffb4 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:1197: ? @ 0x00000000265fd4e7 9. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:62: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x00000000265e6fbd 10. ./contrib/llvm-project/libcxx/include/future:1123: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x00000000265e7bb3 11. DB::ReadBuffer::next() @ 0x000000000b528aeb 12. DB::ReadBuffer::readStrict(char*, unsigned long) @ 0x000000000b581216 13. ./build_docker/./src/Compression/CompressedReadBufferBase.cpp:0: DB::CompressedReadBufferBase::readCompressedData(unsigned long&, unsigned long&, bool) @ 0x000000002775f390 14. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:122: DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x0000000027764cac 15. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:222: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x0000000027ba5430 16. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:0: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x0000000027aa00db 17. ./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>>>*) @ 0x000000002c7b254b 18. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7eb79e 19. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:118: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7c9d8a 20. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x000000002c7e0473 21. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x000000002c7dbec3 22. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:0: DB::MergeTreeReadTask::read(DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002c82d05b 23. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:38: DB::MergeTreeThreadSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&, DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002de66094 24. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:0: DB::MergeTreeSelectProcessor::read() @ 0x000000002c8242f9 25. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000002de6d77a 26. ./build_docker/./src/Processors/ISource.cpp:0: DB::ISource::work() @ 0x000000002d3290a1 27. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 28. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 29. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:381: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000002d34bd35 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7eaf0 31. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001af8a79f 2025.09.09 14:54:46.795999 [ 4022 ] {c3e16843-4abf-4a94-83b9-0fc36039e9c1} virtual DB::ConcurrentHashJoin::~ConcurrentHashJoin(): Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=7, 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af80b71 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af82f33 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000287ae4d3 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:216: DB::JoiningTransform::~JoiningTransform() @ 0x000000002d9d146b 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:216: std::vector, std::allocator>>::__destroy_vector::operator()[abi:v15007]() @ 0x00000000260eaf4e 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:313: std::__shared_ptr_emplace, std::allocator>>, std::allocator, std::allocator>>>>::__on_zero_shared() @ 0x000000002781a4f7 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:216: DB::QueryPipeline::~QueryPipeline() @ 0x00000000278210b3 11. ./build_docker/./src/QueryPipeline/QueryPipeline.cpp:698: DB::QueryPipeline::reset() @ 0x000000002782d48a 12. ./build_docker/./src/Server/TCPHandler.cpp:680: DB::TCPHandler::runImpl() @ 0x000000002d178c28 13. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 18. asan_thread_start(void*) @ 0x000000000aa43059 19. ? @ 0x00007f35aab92ac3 20. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:54:46.819854 [ 2686 ] {77467a85-f64c-46d0-9f6f-3acdb9fae10e} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=6, jobs=0): (while reading column value): (while reading from part /var/lib/clickhouse/store/3b7/3b7f9237-6979-480e-af74-6371475b2898/all_2_2_0/ in table test_1.num_2 (3b7f9237-6979-480e-af74-6371475b2898) located on disk default of type local, from mark 2 with max_rows_to_read = 57344): While executing MergeTreeSelect(pool: ReadPoolParallelReplicas, algorithm: Thread). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af80b71 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80746 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000266005a2 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000265fffb4 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:1197: ? @ 0x00000000265fd4e7 9. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:62: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x00000000265e6fbd 10. ./contrib/llvm-project/libcxx/include/future:1123: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x00000000265e7bb3 11. DB::ReadBuffer::next() @ 0x000000000b528aeb 12. DB::ReadBuffer::readStrict(char*, unsigned long) @ 0x000000000b581216 13. ./build_docker/./src/Compression/CompressedReadBufferBase.cpp:0: DB::CompressedReadBufferBase::readCompressedData(unsigned long&, unsigned long&, bool) @ 0x000000002775f390 14. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:122: DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x0000000027764cac 15. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:222: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x0000000027ba5430 16. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:0: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x0000000027aa00db 17. ./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>>>*) @ 0x000000002c7b254b 18. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7eb79e 19. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:118: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7c9d8a 20. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x000000002c7e0473 21. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x000000002c7dbec3 22. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:0: DB::MergeTreeReadTask::read(DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002c82d05b 23. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:38: DB::MergeTreeThreadSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&, DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002de66094 24. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:0: DB::MergeTreeSelectProcessor::read() @ 0x000000002c8242f9 25. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000002de6d77a 26. ./build_docker/./src/Processors/ISource.cpp:0: DB::ISource::work() @ 0x000000002d3290a1 27. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 28. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 29. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:381: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000002d34bd35 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7eaf0 31. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001af8a79f 2025.09.09 14:54:46.836821 [ 3163 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:54:46.843349 [ 4022 ] {c3e16843-4abf-4a94-83b9-0fc36039e9c1} TCPHandler: Can't send logs to client: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::ffff:127.0.0.2]:9000 -> [::ffff:127.0.0.1]:47796). (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 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&&) @ 0x000000001b0b7a5f 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:169: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000001b0bada2 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:201: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000002cf09bf7 5. ./src/IO/WriteBuffer.h:66: DB::TCPHandler::sendLogData(DB::Block const&) @ 0x000000002d1a9beb 6. ./contrib/llvm-project/libcxx/include/__hash_table:1473: DB::TCPHandler::sendLogs() @ 0x000000002d18db59 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d176902 8. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 12. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 13. asan_thread_start(void*) @ 0x000000000aa43059 14. ? @ 0x00007f35aab92ac3 15. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:54:46.849715 [ 4022 ] {c3e16843-4abf-4a94-83b9-0fc36039e9c1} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=7, jobs=2). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af80b71 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80746 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d34b5ca 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000002d3486e4 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000002d34827b 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002d36bcf7 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 12. asan_thread_start(void*) @ 0x000000000aa43059 13. ? @ 0x00007f35aab92ac3 14. ? @ 0x00007f35aac24850 2025.09.09 14:54:46.852372 [ 4022 ] {c3e16843-4abf-4a94-83b9-0fc36039e9c1} TCPHandler: Client has gone away. 2025.09.09 14:54:46.886630 [ 3167 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:54:46.916980 [ 3722 ] {c57025e6-5bb1-4d5b-a102-d9f6c5625611} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=773, jobs=729). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:33512) (comment: 02876_s3_cluster_schema_inference_names_with_spaces.sql) (in query: desc s3Cluster(test_cluster_one_shard_three_replicas_localhost, 'http://localhost:11111/test/02876.parquet');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af872f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af7b2d1 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af7c3f3 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d36920d 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000002d369e5f 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processOrdinaryQuery() @ 0x000000002d18af7b 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d17644a 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 15. asan_thread_start(void*) @ 0x000000000aa43059 16. ? @ 0x00007f35aab92ac3 17. ? @ 0x00007f35aac24850 2025.09.09 14:54:46.931917 [ 3722 ] {c57025e6-5bb1-4d5b-a102-d9f6c5625611} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=773, jobs=729). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af872f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af7b2d1 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af7c3f3 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d36920d 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000002d369e5f 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processOrdinaryQuery() @ 0x000000002d18af7b 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d17644a 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 15. asan_thread_start(void*) @ 0x000000000aa43059 16. ? @ 0x00007f35aab92ac3 17. ? @ 0x00007f35aac24850 2025.09.09 14:54:46.948966 [ 2686 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 14:54:47.577731 [ 2686 ] {0172e784-e40a-4885-9017-b6d5525dcb22} 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af819ed 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af82f33 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000287ad950 7. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:35: DB::chooseJoinAlgorithm(std::shared_ptr&, std::shared_ptr const&, DB::Block const&, DB::Block const&, std::shared_ptr const&) @ 0x00000000294a6614 8. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1490: DB::(anonymous namespace)::buildQueryPlanForJoinNode(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000002947642f 9. ./build_docker/./src/Planner/PlannerJoinTree.cpp:0: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000002945f174 10. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x000000002942c986 11. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x00000000294261fb 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::getSampleBlock(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000294204da 13. ./build_docker/./src/Planner/findParallelReplicasQuery.cpp:412: DB::buildQueryPlanForParallelReplicas(DB::QueryNode const&, std::shared_ptr const&, std::shared_ptr> const>) @ 0x0000000029451774 14. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x000000002942cb63 15. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x00000000294261fb 16. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000029421552 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1182: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3737e 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 20. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 24. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 25. asan_thread_start(void*) @ 0x000000000aa43059 26. ? @ 0x00007f35aab92ac3 27. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:54:47.591909 [ 2686 ] {0172e784-e40a-4885-9017-b6d5525dcb22} 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.10505.altinitytest (altinity build)) (from [::1]:33526) (comment: 02967_parallel_replicas_join_algo_and_analyzer_3.sh) (in query: select * from (select key, value from num_1) l inner join (select key, value from num_2 inner join (select number * 7 as key from numbers(1e5)) as nn on num_2.key = nn.key settings parallel_replicas_prefer_local_join=0) r on l.key = r.key order by l.key limit 10 offset 10000 SETTINGS enable_analyzer=1, enable_parallel_replicas = 2, max_parallel_replicas = 2, parallel_replicas_for_non_replicated_merge_tree = 1, cluster_for_parallel_replicas = 'test_cluster_one_shard_three_replicas_localhost', parallel_replicas_local_plan=1, send_logs_level='trace', parallel_replicas_prefer_local_join=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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af819ed 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af82f33 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000287ad950 7. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:35: DB::chooseJoinAlgorithm(std::shared_ptr&, std::shared_ptr const&, DB::Block const&, DB::Block const&, std::shared_ptr const&) @ 0x00000000294a6614 8. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1490: DB::(anonymous namespace)::buildQueryPlanForJoinNode(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000002947642f 9. ./build_docker/./src/Planner/PlannerJoinTree.cpp:0: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000002945f174 10. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x000000002942c986 11. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x00000000294261fb 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::getSampleBlock(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000294204da 13. ./build_docker/./src/Planner/findParallelReplicasQuery.cpp:412: DB::buildQueryPlanForParallelReplicas(DB::QueryNode const&, std::shared_ptr const&, std::shared_ptr> const>) @ 0x0000000029451774 14. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x000000002942cb63 15. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x00000000294261fb 16. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000029421552 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1182: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3737e 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 20. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 24. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 25. asan_thread_start(void*) @ 0x000000000aa43059 26. ? @ 0x00007f35aab92ac3 27. ? @ 0x00007f35aac24850 2025.09.09 14:54:47.647425 [ 2686 ] {0172e784-e40a-4885-9017-b6d5525dcb22} 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af819ed 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af82f33 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000287ad950 7. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:35: DB::chooseJoinAlgorithm(std::shared_ptr&, std::shared_ptr const&, DB::Block const&, DB::Block const&, std::shared_ptr const&) @ 0x00000000294a6614 8. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1490: DB::(anonymous namespace)::buildQueryPlanForJoinNode(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000002947642f 9. ./build_docker/./src/Planner/PlannerJoinTree.cpp:0: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000002945f174 10. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x000000002942c986 11. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x00000000294261fb 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::getSampleBlock(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000294204da 13. ./build_docker/./src/Planner/findParallelReplicasQuery.cpp:412: DB::buildQueryPlanForParallelReplicas(DB::QueryNode const&, std::shared_ptr const&, std::shared_ptr> const>) @ 0x0000000029451774 14. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x000000002942cb63 15. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x00000000294261fb 16. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000029421552 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1182: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3737e 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 20. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 24. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 25. asan_thread_start(void*) @ 0x000000000aa43059 26. ? @ 0x00007f35aab92ac3 27. ? @ 0x00007f35aac24850 2025.09.09 14:54:47.887412 [ 3186 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:54:47.888612 [ 3183 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:54:48.075741 [ 3640 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 14:54:48.235689 [ 2686 ] {80811fe5-7f6b-46bd-ae7b-8d4cd05386ba} virtual DB::ConcurrentHashJoin::~ConcurrentHashJoin(): Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=6, jobs=2). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af80b71 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af82f33 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000287ae4d3 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:216: DB::JoinStep::~JoinStep() @ 0x000000002ddd8c62 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: std::__list_imp>::clear() @ 0x000000002de1141e 9. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:32: DB::QueryPlan::~QueryPlan() @ 0x000000002ddfbf12 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Planner::~Planner() @ 0x00000000287a4997 11. ./build_docker/./src/Planner/findParallelReplicasQuery.cpp:0: DB::findQueryForParallelReplicas(std::shared_ptr const&, DB::SelectQueryOptions&) @ 0x000000002944fa87 12. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::Planner(std::shared_ptr const&, DB::SelectQueryOptions&) @ 0x0000000029422d2e 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:163: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000029419c66 14. ./contrib/llvm-project/libcxx/include/vector:432: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000029421f5d 15. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000029344c1b 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*) @ 0x0000000029b3703b 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 19. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 23. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 24. asan_thread_start(void*) @ 0x000000000aa43059 25. ? @ 0x00007f35aab92ac3 26. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:54:48.292627 [ 2686 ] {80811fe5-7f6b-46bd-ae7b-8d4cd05386ba} 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=6, 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af819ed 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af82f33 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000287ad950 7. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:35: DB::chooseJoinAlgorithm(std::shared_ptr&, std::shared_ptr const&, DB::Block const&, DB::Block const&, std::shared_ptr const&) @ 0x00000000294a6614 8. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1490: DB::(anonymous namespace)::buildQueryPlanForJoinNode(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000002947642f 9. ./build_docker/./src/Planner/PlannerJoinTree.cpp:0: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000002945f174 10. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x000000002942c986 11. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x00000000294261fb 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::getSampleBlock(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000294204da 13. ./build_docker/./src/Planner/findParallelReplicasQuery.cpp:412: DB::buildQueryPlanForParallelReplicas(DB::QueryNode const&, std::shared_ptr const&, std::shared_ptr> const>) @ 0x0000000029451774 14. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x000000002942cb63 15. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x00000000294261fb 16. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000029421552 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1182: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3737e 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 20. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 24. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 25. asan_thread_start(void*) @ 0x000000000aa43059 26. ? @ 0x00007f35aab92ac3 27. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:54:48.347273 [ 2686 ] {80811fe5-7f6b-46bd-ae7b-8d4cd05386ba} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=6, jobs=5). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:33546) (comment: 02967_parallel_replicas_join_algo_and_analyzer_3.sh) (in query: select * from (select key, value from num_1) l inner join (select key, value from num_2 inner join (select number * 7 as key from numbers(1e5)) as nn on num_2.key = nn.key settings parallel_replicas_prefer_local_join=1) r on l.key = r.key order by l.key limit 10 offset 10000 SETTINGS enable_analyzer=1, enable_parallel_replicas = 2, max_parallel_replicas = 2, parallel_replicas_for_non_replicated_merge_tree = 1, cluster_for_parallel_replicas = 'test_cluster_one_shard_three_replicas_localhost', parallel_replicas_local_plan=1, parallel_replicas_prefer_local_join=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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af819ed 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af82f33 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000287ad950 7. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:35: DB::chooseJoinAlgorithm(std::shared_ptr&, std::shared_ptr const&, DB::Block const&, DB::Block const&, std::shared_ptr const&) @ 0x00000000294a6614 8. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1490: DB::(anonymous namespace)::buildQueryPlanForJoinNode(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000002947642f 9. ./build_docker/./src/Planner/PlannerJoinTree.cpp:0: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000002945f174 10. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x000000002942c986 11. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x00000000294261fb 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::getSampleBlock(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000294204da 13. ./build_docker/./src/Planner/findParallelReplicasQuery.cpp:412: DB::buildQueryPlanForParallelReplicas(DB::QueryNode const&, std::shared_ptr const&, std::shared_ptr> const>) @ 0x0000000029451774 14. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x000000002942cb63 15. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x00000000294261fb 16. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000029421552 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1182: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3737e 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 20. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 24. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 25. asan_thread_start(void*) @ 0x000000000aa43059 26. ? @ 0x00007f35aab92ac3 27. ? @ 0x00007f35aac24850 2025.09.09 14:54:48.355741 [ 2686 ] {80811fe5-7f6b-46bd-ae7b-8d4cd05386ba} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=6, 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af819ed 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af82f33 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000287ad950 7. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:35: DB::chooseJoinAlgorithm(std::shared_ptr&, std::shared_ptr const&, DB::Block const&, DB::Block const&, std::shared_ptr const&) @ 0x00000000294a6614 8. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1490: DB::(anonymous namespace)::buildQueryPlanForJoinNode(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000002947642f 9. ./build_docker/./src/Planner/PlannerJoinTree.cpp:0: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000002945f174 10. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x000000002942c986 11. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x00000000294261fb 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::getSampleBlock(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000294204da 13. ./build_docker/./src/Planner/findParallelReplicasQuery.cpp:412: DB::buildQueryPlanForParallelReplicas(DB::QueryNode const&, std::shared_ptr const&, std::shared_ptr> const>) @ 0x0000000029451774 14. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x000000002942cb63 15. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x00000000294261fb 16. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000029421552 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1182: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3737e 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 20. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 24. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 25. asan_thread_start(void*) @ 0x000000000aa43059 26. ? @ 0x00007f35aab92ac3 27. ? @ 0x00007f35aac24850 2025.09.09 14:54:48.758216 [ 2686 ] {aaf7e34f-16e9-4a7d-9105-729e0eebce2f} virtual DB::ConcurrentHashJoin::~ConcurrentHashJoin(): 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af80b71 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af82f33 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000287ae4d3 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:216: DB::JoinStep::~JoinStep() @ 0x000000002ddd8c62 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: std::__list_imp>::clear() @ 0x000000002de1141e 9. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:32: DB::QueryPlan::~QueryPlan() @ 0x000000002ddfbf12 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Planner::~Planner() @ 0x00000000287a4997 11. ./build_docker/./src/Planner/findParallelReplicasQuery.cpp:0: DB::findQueryForParallelReplicas(std::shared_ptr const&, DB::SelectQueryOptions&) @ 0x000000002944fa87 12. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::Planner(std::shared_ptr const&, DB::SelectQueryOptions&) @ 0x0000000029422d2e 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:163: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000029419c66 14. ./contrib/llvm-project/libcxx/include/vector:432: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000029421f5d 15. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000029344c1b 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*) @ 0x0000000029b3703b 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 19. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 23. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 24. asan_thread_start(void*) @ 0x000000000aa43059 25. ? @ 0x00007f35aab92ac3 26. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:54:48.774357 [ 2686 ] {aaf7e34f-16e9-4a7d-9105-729e0eebce2f} virtual DB::ConcurrentHashJoin::~ConcurrentHashJoin(): Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=8, jobs=2). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af80b71 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af82f33 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000287ae4d3 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:216: DB::JoinStep::~JoinStep() @ 0x000000002ddd8c62 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: std::__list_imp>::clear() @ 0x000000002de1141e 9. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:32: DB::QueryPlan::~QueryPlan() @ 0x000000002ddfbf12 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Planner::~Planner() @ 0x00000000287a4997 11. ./build_docker/./src/Planner/findParallelReplicasQuery.cpp:0: DB::findQueryForParallelReplicas(std::shared_ptr const&, DB::SelectQueryOptions&) @ 0x000000002944fa87 12. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::Planner(std::shared_ptr const&, DB::SelectQueryOptions&) @ 0x0000000029422d2e 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:163: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000029419c66 14. ./contrib/llvm-project/libcxx/include/vector:432: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000029421f5d 15. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000029344c1b 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*) @ 0x0000000029b3703b 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 19. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 23. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 24. asan_thread_start(void*) @ 0x000000000aa43059 25. ? @ 0x00007f35aab92ac3 26. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:54:48.889836 [ 3228 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:54:48.891087 [ 3230 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:54:49.188329 [ 4023 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 14:54:49.485762 [ 2686 ] {aaf7e34f-16e9-4a7d-9105-729e0eebce2f} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=7, jobs=7). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:40946) (comment: 02967_parallel_replicas_join_algo_and_analyzer_3.sh) (in query: select * from (select key, value from num_1) l inner join (select key, value from num_2 inner join (select number * 7 as key from numbers(1e5)) as nn on num_2.key = nn.key settings parallel_replicas_prefer_local_join=1) r on l.key = r.key order by l.key limit 10 offset 10000 SETTINGS enable_analyzer=1, enable_parallel_replicas = 2, max_parallel_replicas = 2, parallel_replicas_for_non_replicated_merge_tree = 1, cluster_for_parallel_replicas = 'test_cluster_one_shard_three_replicas_localhost', parallel_replicas_local_plan=1, send_logs_level='trace', parallel_replicas_prefer_local_join=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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af80b71 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80746 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d34b5ca 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000002d3486e4 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000002d34827b 9. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:113: DB::CompletedPipelineExecutor::execute() @ 0x000000002d34579e 10. ./build_docker/./src/Storages/buildQueryTreeForShard.cpp:0: DB::(anonymous namespace)::executeSubqueryNode(std::shared_ptr const&, std::shared_ptr&, unsigned long) @ 0x000000002bde6f5c 11. ./build_docker/./src/Storages/buildQueryTreeForShard.cpp:355: DB::buildQueryTreeForShard(std::shared_ptr const&, std::shared_ptr) @ 0x000000002bddfa63 12. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::buildQueryPlanForParallelReplicas(DB::QueryNode const&, std::shared_ptr const&, std::shared_ptr> const>) @ 0x0000000029451818 13. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x000000002942cb63 14. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x00000000294261fb 15. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000029421552 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1182: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3737e 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 19. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 23. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 24. asan_thread_start(void*) @ 0x000000000aa43059 25. ? @ 0x00007f35aab92ac3 26. ? @ 0x00007f35aac24850 2025.09.09 14:54:49.529034 [ 2686 ] {aaf7e34f-16e9-4a7d-9105-729e0eebce2f} 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af80b71 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80746 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d34b5ca 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000002d3486e4 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000002d34827b 9. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:113: DB::CompletedPipelineExecutor::execute() @ 0x000000002d34579e 10. ./build_docker/./src/Storages/buildQueryTreeForShard.cpp:0: DB::(anonymous namespace)::executeSubqueryNode(std::shared_ptr const&, std::shared_ptr&, unsigned long) @ 0x000000002bde6f5c 11. ./build_docker/./src/Storages/buildQueryTreeForShard.cpp:355: DB::buildQueryTreeForShard(std::shared_ptr const&, std::shared_ptr) @ 0x000000002bddfa63 12. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::buildQueryPlanForParallelReplicas(DB::QueryNode const&, std::shared_ptr const&, std::shared_ptr> const>) @ 0x0000000029451818 13. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x000000002942cb63 14. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x00000000294261fb 15. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000029421552 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1182: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3737e 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 19. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 23. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 24. asan_thread_start(void*) @ 0x000000000aa43059 25. ? @ 0x00007f35aab92ac3 26. ? @ 0x00007f35aac24850 2025.09.09 14:54:49.891914 [ 2756 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:54:49.892948 [ 2743 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:54:50.210543 [ 4023 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 14:54:50.894284 [ 2748 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:54:50.894948 [ 2768 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:54:50.967425 [ 4019 ] {3e415868-640a-4f7e-92f5-cb2368999035} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=773, jobs=737). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:49878) (comment: 01825_replacing_vertical_merge.sql) (in query: SELECT sum(`__table1`.`a`) AS `sum(a)`, count() AS `count()` FROM `test_3`.`replacing_table` AS `__table1`), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af872f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af7b2d1 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af7c3f3 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d36920d 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000002d369e5f 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processOrdinaryQuery() @ 0x000000002d18af7b 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d17644a 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 15. asan_thread_start(void*) @ 0x000000000aa43059 16. ? @ 0x00007f35aab92ac3 17. ? @ 0x00007f35aac24850 2025.09.09 14:54:50.970230 [ 4019 ] {3e415868-640a-4f7e-92f5-cb2368999035} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=773, 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af872f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af7b2d1 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af7c3f3 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d36920d 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000002d369e5f 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processOrdinaryQuery() @ 0x000000002d18af7b 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d17644a 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 15. asan_thread_start(void*) @ 0x000000000aa43059 16. ? @ 0x00007f35aab92ac3 17. ? @ 0x00007f35aac24850 2025.09.09 14:54:50.987613 [ 2686 ] {51c23489-4b22-43e8-98f9-1cbecd86df61} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=3, jobs=3). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:40970) (comment: 02967_parallel_replicas_join_algo_and_analyzer_3.sh) (in query: select * from (select key, value from num_1) l inner join (select key, value from num_2 inner join (select number * 7 as key from numbers(1e5)) as nn on num_2.key = nn.key settings join_algorithm='full_sorting_merge') r on l.key = r.key order by l.key limit 10 offset 10000 SETTINGS enable_analyzer=1, enable_parallel_replicas = 2, max_parallel_replicas = 2, parallel_replicas_for_non_replicated_merge_tree = 1, cluster_for_parallel_replicas = 'test_cluster_one_shard_three_replicas_localhost', parallel_replicas_local_plan=1, parallel_replicas_prefer_local_join=0, 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af80b71 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80746 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d34b5ca 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000002d3486e4 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000002d34827b 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002d36bcf7 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 12. asan_thread_start(void*) @ 0x000000000aa43059 13. ? @ 0x00007f35aab92ac3 14. ? @ 0x00007f35aac24850 2025.09.09 14:54:50.988518 [ 4021 ] {9f6a46ab-7fd1-417a-8def-a20a8782a716} executeQuery: Code: 439. DB::Exception: Received from 127.0.0.8:9000. DB::Exception: Cannot schedule a task: fault injected (threads=773, jobs=737). Stack trace: 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af872f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af7b2d1 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af7c3f3 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d36920d 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000002d369e5f 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processOrdinaryQuery() @ 0x000000002d18af7b 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d17644a 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 15. asan_thread_start(void*) @ 0x000000000aa43059 16. ? @ 0x00007f35aab92ac3 17. ? @ 0x00007f35aac24850 : While executing Remote. (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:33542) (comment: 01825_replacing_vertical_merge.sql) (in query: SELECT sum(a), count() FROM replacing_table;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. ./contrib/llvm-project/libcxx/include/string:1499: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x000000001aeb974e 3. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::Connection::receiveException() const @ 0x000000002cee6c6a 4. ./build_docker/./src/Client/Connection.cpp:0: DB::Connection::receivePacket() @ 0x000000002cef780e 5. ./build_docker/./src/Client/MultiplexedConnections.cpp:340: DB::MultiplexedConnections::receivePacketUnlocked(std::function) @ 0x000000002cf8e09e 6. ./build_docker/./src/QueryPipeline/RemoteQueryExecutorReadContext.cpp:0: DB::RemoteQueryExecutorReadContext::Task::run(std::function, std::function) @ 0x00000000278ad616 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000278ab436 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000278aaa44 9. ./contrib/boost/boost/context/fiber_ucontext.hpp:82: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x00000000278a8394 2025.09.09 14:54:50.998932 [ 4021 ] {9f6a46ab-7fd1-417a-8def-a20a8782a716} TCPHandler: Code: 439. DB::Exception: Received from 127.0.0.8:9000. DB::Exception: Cannot schedule a task: fault injected (threads=773, jobs=737). Stack trace: 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af872f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af7b2d1 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af7c3f3 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d36920d 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000002d369e5f 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processOrdinaryQuery() @ 0x000000002d18af7b 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d17644a 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 15. asan_thread_start(void*) @ 0x000000000aa43059 16. ? @ 0x00007f35aab92ac3 17. ? @ 0x00007f35aac24850 : 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. ./contrib/llvm-project/libcxx/include/string:1499: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x000000001aeb974e 3. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::Connection::receiveException() const @ 0x000000002cee6c6a 4. ./build_docker/./src/Client/Connection.cpp:0: DB::Connection::receivePacket() @ 0x000000002cef780e 5. ./build_docker/./src/Client/MultiplexedConnections.cpp:340: DB::MultiplexedConnections::receivePacketUnlocked(std::function) @ 0x000000002cf8e09e 6. ./build_docker/./src/QueryPipeline/RemoteQueryExecutorReadContext.cpp:0: DB::RemoteQueryExecutorReadContext::Task::run(std::function, std::function) @ 0x00000000278ad616 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000278ab436 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000278aaa44 9. ./contrib/boost/boost/context/fiber_ucontext.hpp:82: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x00000000278a8394 2025.09.09 14:54:51.000306 [ 3640 ] {3bcfe977-0d27-485d-8d6d-27d5b16cc4a2} executeQuery: Code: 210. DB::NetException: Connection reset by peer, while writing to socket ([::ffff:127.0.0.5]:9000 -> [::ffff:127.0.0.1]:41042). (NETWORK_ERROR) (version 24.8.14.10505.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:41042) (comment: 01825_replacing_vertical_merge.sql) (in query: SELECT sum(`__table1`.`a`) AS `sum(a)`, count() AS `count()` FROM `test_3`.`replacing_table` AS `__table1`), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 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&&) @ 0x000000001b0b7a5f 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:158: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000001b0bab02 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:201: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000002cf09bf7 5. ./src/IO/WriteBuffer.h:66: DB::TCPHandler::sendEndOfStream() @ 0x000000002d18e36e 6. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d176757 7. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 11. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 12. asan_thread_start(void*) @ 0x000000000aa43059 13. ? @ 0x00007f35aab92ac3 14. ? @ 0x00007f35aac24850 2025.09.09 14:54:51.017257 [ 3640 ] {3bcfe977-0d27-485d-8d6d-27d5b16cc4a2} TCPHandler: Can't send logs to client: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::ffff:127.0.0.5]:9000 -> [::ffff:127.0.0.1]:41042). (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 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&&) @ 0x000000001b0b7a5f 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:169: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000001b0bada2 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:201: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000002cf09bf7 5. ./src/IO/WriteBuffer.h:66: DB::TCPHandler::sendLogData(DB::Block const&) @ 0x000000002d1a9beb 6. ./contrib/llvm-project/libcxx/include/__hash_table:1473: DB::TCPHandler::sendLogs() @ 0x000000002d18db59 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d176902 8. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 12. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 13. asan_thread_start(void*) @ 0x000000000aa43059 14. ? @ 0x00007f35aab92ac3 15. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:54:51.020138 [ 3640 ] {3bcfe977-0d27-485d-8d6d-27d5b16cc4a2} TCPHandler: Code: 210. DB::NetException: Connection reset by peer, while writing to socket ([::ffff:127.0.0.5]:9000 -> [::ffff:127.0.0.1]:41042). (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 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&&) @ 0x000000001b0b7a5f 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:158: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000001b0bab02 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:201: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000002cf09bf7 5. ./src/IO/WriteBuffer.h:66: DB::TCPHandler::sendEndOfStream() @ 0x000000002d18e36e 6. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d176757 7. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 11. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 12. asan_thread_start(void*) @ 0x000000000aa43059 13. ? @ 0x00007f35aab92ac3 14. ? @ 0x00007f35aac24850 2025.09.09 14:54:51.027243 [ 3640 ] {3bcfe977-0d27-485d-8d6d-27d5b16cc4a2} TCPHandler: Client has gone away. 2025.09.09 14:54:51.064775 [ 2686 ] {51c23489-4b22-43e8-98f9-1cbecd86df61} 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af80b71 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80746 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d34b5ca 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000002d3486e4 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000002d34827b 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002d36bcf7 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 12. asan_thread_start(void*) @ 0x000000000aa43059 13. ? @ 0x00007f35aab92ac3 14. ? @ 0x00007f35aac24850 2025.09.09 14:54:51.172476 [ 5359 ] {481a3530-2b01-4ea1-93cb-896be4cbc52c} executeQuery: Code: 210. DB::NetException: Connection reset by peer, while writing to socket ([::ffff:127.0.0.10]:9000 -> [::ffff:127.0.0.1]:55134). (NETWORK_ERROR) (version 24.8.14.10505.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:55134) (comment: 01825_replacing_vertical_merge.sql) (in query: SELECT sum(`__table1`.`a`) AS `sum(a)`, count() AS `count()` FROM `test_3`.`replacing_table` AS `__table1`), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 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&&) @ 0x000000001b0b7a5f 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:158: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000001b0bab02 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:201: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000002cf09bf7 5. ./src/IO/WriteBuffer.h:66: DB::TCPHandler::sendData(DB::Block const&) @ 0x000000002d190f6b 6. ./contrib/llvm-project/libcxx/include/__hash_table:1473: DB::TCPHandler::processOrdinaryQuery() @ 0x000000002d18b989 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d17644a 8. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 12. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 13. asan_thread_start(void*) @ 0x000000000aa43059 14. ? @ 0x00007f35aab92ac3 15. ? @ 0x00007f35aac24850 2025.09.09 14:54:51.194562 [ 5359 ] {481a3530-2b01-4ea1-93cb-896be4cbc52c} TCPHandler: Can't send logs to client: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::ffff:127.0.0.10]:9000 -> [::ffff:127.0.0.1]:55134). (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 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&&) @ 0x000000001b0b7a5f 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:169: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000001b0bada2 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:201: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000002cf09bf7 5. ./src/IO/WriteBuffer.h:66: DB::TCPHandler::sendLogData(DB::Block const&) @ 0x000000002d1a9beb 6. ./contrib/llvm-project/libcxx/include/__hash_table:1473: DB::TCPHandler::sendLogs() @ 0x000000002d18db59 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d176902 8. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 12. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 13. asan_thread_start(void*) @ 0x000000000aa43059 14. ? @ 0x00007f35aab92ac3 15. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:54:51.199187 [ 5359 ] {481a3530-2b01-4ea1-93cb-896be4cbc52c} TCPHandler: Code: 210. DB::NetException: Connection reset by peer, while writing to socket ([::ffff:127.0.0.10]:9000 -> [::ffff:127.0.0.1]:55134). (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 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&&) @ 0x000000001b0b7a5f 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:158: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000001b0bab02 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:201: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000002cf09bf7 5. ./src/IO/WriteBuffer.h:66: DB::TCPHandler::sendData(DB::Block const&) @ 0x000000002d190f6b 6. ./contrib/llvm-project/libcxx/include/__hash_table:1473: DB::TCPHandler::processOrdinaryQuery() @ 0x000000002d18b989 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d17644a 8. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 12. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 13. asan_thread_start(void*) @ 0x000000000aa43059 14. ? @ 0x00007f35aab92ac3 15. ? @ 0x00007f35aac24850 2025.09.09 14:54:51.205875 [ 5359 ] {481a3530-2b01-4ea1-93cb-896be4cbc52c} TCPHandler: Client has gone away. 2025.09.09 14:54:51.325031 [ 2686 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 14:54:51.896300 [ 2785 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:54:51.897000 [ 2794 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:54:51.924383 [ 4023 ] {bcf46425-b206-4707-bb88-248369f082e4} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=10, jobs=10). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:56798) (comment: 02967_parallel_replicas_join_algo_and_analyzer_3.sh) (in query: SELECT `__table1`.`key` AS `key`, `__table1`.`value` AS `value` FROM `test_1`.`num_2` AS `__table1` GLOBAL ALL INNER JOIN `_data_6159103449907252772_9558241464499801717` AS `__table2` ON `__table1`.`key` = `__table2`.`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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af80b71 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80746 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d34b5ca 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:306: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349fbb 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:381: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000002d34bd35 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7eaf0 10. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001af8a79f 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 13. asan_thread_start(void*) @ 0x000000000aa43059 14. ? @ 0x00007f35aab92ac3 15. ? @ 0x00007f35aac24850 2025.09.09 14:54:51.928294 [ 4023 ] {bcf46425-b206-4707-bb88-248369f082e4} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=10, jobs=10). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af80b71 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80746 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d34b5ca 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:306: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349fbb 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:381: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000002d34bd35 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7eaf0 10. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001af8a79f 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 13. asan_thread_start(void*) @ 0x000000000aa43059 14. ? @ 0x00007f35aab92ac3 15. ? @ 0x00007f35aac24850 2025.09.09 14:54:51.989961 [ 2686 ] {f2ac9aa3-e48b-4847-bb6c-e4fd4b039326} executeQuery: Code: 36. DB::Exception: Regexp length too large (2 > 1): In scope SELECT multiMatchAny('123', ['12']). (BAD_ARGUMENTS) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:40996) (comment: 02004_max_hyperscan_regex_length.sql) (in query: select multiMatchAny('123', ['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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&&, unsigned long&) @ 0x000000000e8444da 4. DB::checkHyperscanRegexp(std::vector>, std::allocator>>> const&, unsigned long, unsigned long) @ 0x000000000e843a80 5. DB::FunctionsMultiStringSearch>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015c0beca 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aa8c635 7. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aac91d5 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000cccccfb 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000cccc1ab 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccccc2a 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccce65c 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd2030 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002839a3af 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000028367bce 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028366290 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283b62c9 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002835ae03 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000028359104 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000028357f0d 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002921bdcc 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&) @ 0x000000002941f313 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&) @ 0x0000000029419aef 23. ./contrib/llvm-project/libcxx/include/vector:432: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000029421f5d 24. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000029344c1b 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*) @ 0x0000000029b3703b 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 27. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 28. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 2025.09.09 14:54:51.997992 [ 2686 ] {f2ac9aa3-e48b-4847-bb6c-e4fd4b039326} TCPHandler: Code: 36. DB::Exception: Regexp length too large (2 > 1): In scope SELECT multiMatchAny('123', ['12']). (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&&, unsigned long&) @ 0x000000000e8444da 4. DB::checkHyperscanRegexp(std::vector>, std::allocator>>> const&, unsigned long, unsigned long) @ 0x000000000e843a80 5. DB::FunctionsMultiStringSearch>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015c0beca 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aa8c635 7. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aac91d5 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000cccccfb 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000cccc1ab 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccccc2a 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccce65c 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd2030 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002839a3af 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000028367bce 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028366290 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283b62c9 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002835ae03 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000028359104 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000028357f0d 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002921bdcc 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&) @ 0x000000002941f313 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&) @ 0x0000000029419aef 23. ./contrib/llvm-project/libcxx/include/vector:432: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000029421f5d 24. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000029344c1b 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*) @ 0x0000000029b3703b 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 27. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 28. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 2025.09.09 14:54:52.025356 [ 4021 ] {86a87872-2d49-4baf-a39f-76f4029300ee} executeQuery: Code: 439. DB::Exception: Received from 127.0.0.3: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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af80b71 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80746 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d34b5ca 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:306: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349fbb 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:381: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000002d34bd35 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7eaf0 10. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001af8a79f 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 13. asan_thread_start(void*) @ 0x000000000aa43059 14. ? @ 0x00007f35aab92ac3 15. ? @ 0x00007f35aac24850 : While executing Remote. (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:40990) (comment: 02967_parallel_replicas_join_algo_and_analyzer_3.sh) (in query: select * from (select key, value from num_1) l inner join (select key, value from num_2 inner join (select number * 7 as key from numbers(1e5)) as nn on num_2.key = nn.key settings join_algorithm='full_sorting_merge') r on l.key = r.key order by l.key limit 10 offset 10000 SETTINGS enable_analyzer=1, enable_parallel_replicas = 2, max_parallel_replicas = 2, parallel_replicas_for_non_replicated_merge_tree = 1, cluster_for_parallel_replicas = 'test_cluster_one_shard_three_replicas_localhost', parallel_replicas_local_plan=1, parallel_replicas_prefer_local_join=0, send_logs_level='trace', 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. ./contrib/llvm-project/libcxx/include/string:1499: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x000000001aeb974e 3. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::Connection::receiveException() const @ 0x000000002cee6c6a 4. ./build_docker/./src/Client/Connection.cpp:0: DB::Connection::receivePacket() @ 0x000000002cef780e 5. ./build_docker/./src/Client/MultiplexedConnections.cpp:340: DB::MultiplexedConnections::receivePacketUnlocked(std::function) @ 0x000000002cf8e09e 6. ./build_docker/./src/QueryPipeline/RemoteQueryExecutorReadContext.cpp:0: DB::RemoteQueryExecutorReadContext::Task::run(std::function, std::function) @ 0x00000000278ad616 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000278ab436 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000278aaa44 9. ./contrib/boost/boost/context/fiber_ucontext.hpp:82: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x00000000278a8394 2025.09.09 14:54:52.081704 [ 4021 ] {86a87872-2d49-4baf-a39f-76f4029300ee} TCPHandler: Code: 439. DB::Exception: Received from 127.0.0.3: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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af80b71 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80746 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d34b5ca 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:306: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349fbb 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:381: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000002d34bd35 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7eaf0 10. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001af8a79f 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 13. asan_thread_start(void*) @ 0x000000000aa43059 14. ? @ 0x00007f35aab92ac3 15. ? @ 0x00007f35aac24850 : 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. ./contrib/llvm-project/libcxx/include/string:1499: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x000000001aeb974e 3. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::Connection::receiveException() const @ 0x000000002cee6c6a 4. ./build_docker/./src/Client/Connection.cpp:0: DB::Connection::receivePacket() @ 0x000000002cef780e 5. ./build_docker/./src/Client/MultiplexedConnections.cpp:340: DB::MultiplexedConnections::receivePacketUnlocked(std::function) @ 0x000000002cf8e09e 6. ./build_docker/./src/QueryPipeline/RemoteQueryExecutorReadContext.cpp:0: DB::RemoteQueryExecutorReadContext::Task::run(std::function, std::function) @ 0x00000000278ad616 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000278ab436 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000278aaa44 9. ./contrib/boost/boost/context/fiber_ucontext.hpp:82: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x00000000278a8394 2025.09.09 14:54:52.357414 [ 2686 ] {0e6dd347-3468-438b-9ad5-6ac411e34a15} executeQuery: Code: 36. DB::Exception: Total regexp lengths too large (2 > 1): In scope SELECT multiMatchAny('123', ['1', '2']). (BAD_ARGUMENTS) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:40996) (comment: 02004_max_hyperscan_regex_length.sql) (in query: select multiMatchAny('123', ['1', '2']);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, unsigned long&) @ 0x000000000cf794ba 4. DB::checkHyperscanRegexp(std::vector>, std::allocator>>> const&, unsigned long, unsigned long) @ 0x000000000e843b0a 5. DB::FunctionsMultiStringSearch>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015c0beca 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aa8c635 7. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aac91d5 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000cccccfb 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000cccc1ab 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccccc2a 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccce65c 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd2030 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002839a3af 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000028367bce 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028366290 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283b62c9 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002835ae03 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000028359104 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000028357f0d 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002921bdcc 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&) @ 0x000000002941f313 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&) @ 0x0000000029419aef 23. ./contrib/llvm-project/libcxx/include/vector:432: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000029421f5d 24. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000029344c1b 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*) @ 0x0000000029b3703b 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 27. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 28. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 2025.09.09 14:54:52.360500 [ 2686 ] {0e6dd347-3468-438b-9ad5-6ac411e34a15} TCPHandler: Code: 36. DB::Exception: Total regexp lengths too large (2 > 1): In scope SELECT multiMatchAny('123', ['1', '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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, unsigned long&) @ 0x000000000cf794ba 4. DB::checkHyperscanRegexp(std::vector>, std::allocator>>> const&, unsigned long, unsigned long) @ 0x000000000e843b0a 5. DB::FunctionsMultiStringSearch>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015c0beca 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aa8c635 7. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aac91d5 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000cccccfb 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000cccc1ab 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccccc2a 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccce65c 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd2030 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002839a3af 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000028367bce 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028366290 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283b62c9 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002835ae03 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000028359104 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000028357f0d 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002921bdcc 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&) @ 0x000000002941f313 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&) @ 0x0000000029419aef 23. ./contrib/llvm-project/libcxx/include/vector:432: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000029421f5d 24. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000029344c1b 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*) @ 0x0000000029b3703b 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 27. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 28. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 2025.09.09 14:54:52.389319 [ 3640 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 14:54:52.690317 [ 2686 ] {e87181c9-a2bd-4cac-8996-3ea2357bbdee} executeQuery: Code: 36. DB::Exception: Regexp length too large (2 > 1): In scope SELECT multiMatchAnyIndex('123', ['12']). (BAD_ARGUMENTS) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:40996) (comment: 02004_max_hyperscan_regex_length.sql) (in query: select multiMatchAnyIndex('123', ['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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&&, unsigned long&) @ 0x000000000e8444da 4. DB::checkHyperscanRegexp(std::vector>, std::allocator>>> const&, unsigned long, unsigned long) @ 0x000000000e843a80 5. DB::FunctionsMultiStringSearch>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015c1292e 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aa8c635 7. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aac91d5 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000cccccfb 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000cccc1ab 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccccc2a 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccce65c 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd2030 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002839a3af 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000028367bce 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028366290 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283b62c9 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002835ae03 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000028359104 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000028357f0d 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002921bdcc 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&) @ 0x000000002941f313 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&) @ 0x0000000029419aef 23. ./contrib/llvm-project/libcxx/include/vector:432: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000029421f5d 24. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000029344c1b 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*) @ 0x0000000029b3703b 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 27. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 28. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 2025.09.09 14:54:52.698229 [ 2686 ] {e87181c9-a2bd-4cac-8996-3ea2357bbdee} TCPHandler: Code: 36. DB::Exception: Regexp length too large (2 > 1): In scope SELECT multiMatchAnyIndex('123', ['12']). (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&&, unsigned long&) @ 0x000000000e8444da 4. DB::checkHyperscanRegexp(std::vector>, std::allocator>>> const&, unsigned long, unsigned long) @ 0x000000000e843a80 5. DB::FunctionsMultiStringSearch>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015c1292e 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aa8c635 7. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aac91d5 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000cccccfb 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000cccc1ab 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccccc2a 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccce65c 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd2030 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002839a3af 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000028367bce 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028366290 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283b62c9 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002835ae03 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000028359104 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000028357f0d 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002921bdcc 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&) @ 0x000000002941f313 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&) @ 0x0000000029419aef 23. ./contrib/llvm-project/libcxx/include/vector:432: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000029421f5d 24. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000029344c1b 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*) @ 0x0000000029b3703b 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 27. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 28. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 2025.09.09 14:54:52.805907 [ 3612 ] {55be9d91-e39b-4434-8db0-618e9f07069a} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=13, jobs=1): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:33540) (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af80b71 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80746 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002c765aab 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:1197: ? @ 0x000000002c7602b8 8. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x000000002c75fc2b 9. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:0: DB::MergeTreeReaderWide::addStream(DB::ISerialization::SubstreamPath const&, String const&) @ 0x000000002c802c31 10. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:0: void std::__function::__policy_invoker::__call_impl const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x000000002c804a95 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000027a9e455 12. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:106: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x0000000027a9ea65 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:100: DB::MergeTreeReaderWide::addStreams(DB::NameAndTypePair const&, std::shared_ptr const&) @ 0x000000002c7fe815 14. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:0: DB::MergeTreeReaderWide::MergeTreeReaderWide(std::shared_ptr, DB::NamesAndTypesList, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*, DB::MarkCache*, DB::MarkRanges, DB::MergeTreeReaderSettings, std::map, std::allocator>>, std::function const&, int) @ 0x000000002c7fdeea 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) @ 0x000000002c5eb9c6 16. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWide.cpp:43: DB::MergeTreeDataPartWide::getReader(DB::NamesAndTypesList const&, std::shared_ptr const&, DB::MarkRanges const&, std::unordered_map, std::equal_to, std::allocator>> const&, DB::UncompressedCache*, DB::MarkCache*, std::shared_ptr const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) const @ 0x000000002c5e354e 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:44: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x000000002c82a56b 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:295: DB::MergeTreeReadPoolBase::createTask(std::shared_ptr, DB::MarkRanges, DB::MergeTreeReadTask*) const @ 0x000000002de9c234 19. ./build_docker/./src/Storages/MergeTree/MergeTreeReadPoolInOrder.cpp:72: DB::MergeTreeReadPoolInOrder::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x000000002deff671 20. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectAlgorithms.cpp:17: DB::MergeTreeInOrderSelectAlgorithm::getNewTask(DB::IMergeTreeReadPool&, DB::MergeTreeReadTask*) @ 0x000000002dea3919 21. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:0: DB::MergeTreeSelectProcessor::read() @ 0x000000002c8241d2 22. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000002de6d77a 23. ./build_docker/./src/Processors/ISource.cpp:0: DB::ISource::work() @ 0x000000002d3290a1 24. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 26. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:381: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000002d34bd35 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7eaf0 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001af8a79f 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 31. asan_thread_start(void*) @ 0x000000000aa43059 2025.09.09 14:54:52.809554 [ 3612 ] {55be9d91-e39b-4434-8db0-618e9f07069a} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=13, jobs=1): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af80b71 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80746 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002c765aab 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:1197: ? @ 0x000000002c7602b8 8. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x000000002c75fc2b 9. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:0: DB::MergeTreeReaderWide::addStream(DB::ISerialization::SubstreamPath const&, String const&) @ 0x000000002c802c31 10. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:0: void std::__function::__policy_invoker::__call_impl const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x000000002c804a95 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000027a9e455 12. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:106: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x0000000027a9ea65 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:100: DB::MergeTreeReaderWide::addStreams(DB::NameAndTypePair const&, std::shared_ptr const&) @ 0x000000002c7fe815 14. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:0: DB::MergeTreeReaderWide::MergeTreeReaderWide(std::shared_ptr, DB::NamesAndTypesList, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*, DB::MarkCache*, DB::MarkRanges, DB::MergeTreeReaderSettings, std::map, std::allocator>>, std::function const&, int) @ 0x000000002c7fdeea 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) @ 0x000000002c5eb9c6 16. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWide.cpp:43: DB::MergeTreeDataPartWide::getReader(DB::NamesAndTypesList const&, std::shared_ptr const&, DB::MarkRanges const&, std::unordered_map, std::equal_to, std::allocator>> const&, DB::UncompressedCache*, DB::MarkCache*, std::shared_ptr const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) const @ 0x000000002c5e354e 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:44: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x000000002c82a56b 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:295: DB::MergeTreeReadPoolBase::createTask(std::shared_ptr, DB::MarkRanges, DB::MergeTreeReadTask*) const @ 0x000000002de9c234 19. ./build_docker/./src/Storages/MergeTree/MergeTreeReadPoolInOrder.cpp:72: DB::MergeTreeReadPoolInOrder::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x000000002deff671 20. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectAlgorithms.cpp:17: DB::MergeTreeInOrderSelectAlgorithm::getNewTask(DB::IMergeTreeReadPool&, DB::MergeTreeReadTask*) @ 0x000000002dea3919 21. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:0: DB::MergeTreeSelectProcessor::read() @ 0x000000002c8241d2 22. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000002de6d77a 23. ./build_docker/./src/Processors/ISource.cpp:0: DB::ISource::work() @ 0x000000002d3290a1 24. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 26. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:381: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000002d34bd35 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7eaf0 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001af8a79f 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 31. asan_thread_start(void*) @ 0x000000000aa43059 2025.09.09 14:54:52.908994 [ 2808 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:54:52.909817 [ 2809 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:54:52.998551 [ 3640 ] {02b96c10-1bcd-4816-99f8-b91bc5edea84} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=8, jobs=8). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:43258) (comment: 02967_parallel_replicas_join_algo_and_analyzer_3.sh) (in query: SELECT `__table1`.`key` AS `key`, `__table1`.`value` AS `value` FROM `test_1`.`num_2` AS `__table1` GLOBAL ALL INNER JOIN `_data_6159103449907252772_9558241464499801717` AS `__table2` ON `__table1`.`key` = `__table2`.`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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af80b71 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80746 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d34b5ca 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000002d3486e4 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000002d34827b 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002d36bcf7 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 12. asan_thread_start(void*) @ 0x000000000aa43059 13. ? @ 0x00007f35aab92ac3 14. ? @ 0x00007f35aac24850 2025.09.09 14:54:53.005603 [ 3640 ] {02b96c10-1bcd-4816-99f8-b91bc5edea84} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=8, jobs=8). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af80b71 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80746 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d34b5ca 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000002d3486e4 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000002d34827b 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002d36bcf7 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 12. asan_thread_start(void*) @ 0x000000000aa43059 13. ? @ 0x00007f35aab92ac3 14. ? @ 0x00007f35aac24850 2025.09.09 14:54:53.025391 [ 3640 ] {} ServerErrorHandler: Code: 210. DB::NetException: Connection reset by peer, while reading from socket (peer: [::ffff:127.0.0.1]:43258, local: [::ffff:127.0.0.2]:9000). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 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&&) @ 0x000000001b0b7a5f 3. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:83: DB::ReadBufferFromPocoSocketBase::socketReceiveBytesImpl(char*, unsigned long) @ 0x000000001b0b6042 4. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:107: DB::ReadBufferFromPocoSocketBase::nextImpl() @ 0x000000001b0b6b84 5. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:103: DB::ReadBufferFromPocoSocketChunked::nextImpl() @ 0x000000002cf045f6 6. DB::ReadBuffer::next() @ 0x000000000b528aeb 7. ./build_docker/./src/Server/TCPHandler.cpp:383: DB::TCPHandler::runImpl() @ 0x000000002d174fd3 8. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 12. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 13. asan_thread_start(void*) @ 0x000000000aa43059 14. ? @ 0x00007f35aab92ac3 15. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:54:53.033173 [ 2686 ] {9904231a-82c2-4f1a-8e21-135fc261020b} executeQuery: Code: 36. DB::Exception: Total regexp lengths too large (2 > 1): In scope SELECT multiMatchAnyIndex('123', ['1', '2']). (BAD_ARGUMENTS) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:40996) (comment: 02004_max_hyperscan_regex_length.sql) (in query: select multiMatchAnyIndex('123', ['1', '2']);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, unsigned long&) @ 0x000000000cf794ba 4. DB::checkHyperscanRegexp(std::vector>, std::allocator>>> const&, unsigned long, unsigned long) @ 0x000000000e843b0a 5. DB::FunctionsMultiStringSearch>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015c1292e 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aa8c635 7. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aac91d5 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000cccccfb 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000cccc1ab 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccccc2a 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccce65c 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd2030 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002839a3af 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000028367bce 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028366290 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283b62c9 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002835ae03 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000028359104 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000028357f0d 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002921bdcc 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&) @ 0x000000002941f313 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&) @ 0x0000000029419aef 23. ./contrib/llvm-project/libcxx/include/vector:432: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000029421f5d 24. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000029344c1b 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*) @ 0x0000000029b3703b 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 27. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 28. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 2025.09.09 14:54:53.052632 [ 2686 ] {9904231a-82c2-4f1a-8e21-135fc261020b} TCPHandler: Code: 36. DB::Exception: Total regexp lengths too large (2 > 1): In scope SELECT multiMatchAnyIndex('123', ['1', '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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, unsigned long&) @ 0x000000000cf794ba 4. DB::checkHyperscanRegexp(std::vector>, std::allocator>>> const&, unsigned long, unsigned long) @ 0x000000000e843b0a 5. DB::FunctionsMultiStringSearch>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015c1292e 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aa8c635 7. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aac91d5 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000cccccfb 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000cccc1ab 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccccc2a 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccce65c 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd2030 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002839a3af 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000028367bce 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028366290 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283b62c9 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002835ae03 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000028359104 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000028357f0d 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002921bdcc 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&) @ 0x000000002941f313 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&) @ 0x0000000029419aef 23. ./contrib/llvm-project/libcxx/include/vector:432: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000029421f5d 24. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000029344c1b 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*) @ 0x0000000029b3703b 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 27. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 28. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 2025.09.09 14:54:53.140461 [ 2688 ] {180d1097-ba50-4593-accf-1ebf0789236d} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:38672) (comment: 01055_compact_parts.sql) (in query: DROP DATABASE IF EXISTS test_n6c6gygq ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aac868e 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x00000000286b57c7 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x00000000291f5630 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:361: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000291edc97 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x00000000291ebf11 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x00000000291eb7ed 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b382fc 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1529: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000029b3ed3f 11. ./build_docker/./src/Server/HTTPHandler.cpp:529: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000002d0662d1 12. ./build_docker/./src/Server/HTTPHandler.cpp:705: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000002d06d139 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000002d1cc337 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 18. asan_thread_start(void*) @ 0x000000000aa43059 19. ? @ 0x00007f35aab92ac3 20. ? @ 0x00007f35aac24850 2025.09.09 14:54:53.146511 [ 2688 ] {180d1097-ba50-4593-accf-1ebf0789236d} DynamicQueryHandler: Code: 219. DB::Exception: New table 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aac868e 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x00000000286b57c7 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x00000000291f5630 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:361: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000291edc97 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x00000000291ebf11 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x00000000291eb7ed 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b382fc 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1529: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000029b3ed3f 11. ./build_docker/./src/Server/HTTPHandler.cpp:529: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000002d0662d1 12. ./build_docker/./src/Server/HTTPHandler.cpp:705: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000002d06d139 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000002d1cc337 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 18. asan_thread_start(void*) @ 0x000000000aa43059 19. ? @ 0x00007f35aab92ac3 20. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:54:53.278123 [ 4021 ] {8d3e453c-b14c-4460-8560-bb99fc1b07a7} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=9, jobs=0): (while reading column value): (while reading from part /var/lib/clickhouse/store/3b7/3b7f9237-6979-480e-af74-6371475b2898/all_1_1_0/ in table test_1.num_2 (3b7f9237-6979-480e-af74-6371475b2898) located on disk default of type local, from mark 96 with max_rows_to_read = 57344): While executing MergeTreeSelect(pool: ReadPoolParallelReplicas, algorithm: Thread). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:40998) (comment: 02967_parallel_replicas_join_algo_and_analyzer_3.sh) (in query: select * from (select key, value from num_1) l inner join (select key, value from num_2 inner join (select number * 7 as key from numbers(1e5)) as nn on num_2.key = nn.key settings join_algorithm='hash') r on l.key = r.key order by l.key limit 10 offset 10000 SETTINGS enable_analyzer=1, enable_parallel_replicas = 2, max_parallel_replicas = 2, parallel_replicas_for_non_replicated_merge_tree = 1, cluster_for_parallel_replicas = 'test_cluster_one_shard_three_replicas_localhost', parallel_replicas_local_plan=1, parallel_replicas_prefer_local_join=0, 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af80b71 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80746 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000266005a2 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000265fffb4 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:1197: ? @ 0x00000000265fd4e7 9. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:62: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x00000000265e6fbd 10. ./contrib/llvm-project/libcxx/include/future:1123: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x00000000265e7bb3 11. DB::ReadBuffer::next() @ 0x000000000b528aeb 12. DB::ReadBuffer::readStrict(char*, unsigned long) @ 0x000000000b581216 13. ./build_docker/./src/Compression/CompressedReadBufferBase.cpp:0: DB::CompressedReadBufferBase::readCompressedData(unsigned long&, unsigned long&, bool) @ 0x000000002775f390 14. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:122: DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x0000000027764cac 15. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:222: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x0000000027ba5430 16. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:0: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x0000000027aa00db 17. ./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) @ 0x000000002c80211e 18. ./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>>&) @ 0x000000002c800e8d 19. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:118: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7c9d8a 20. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x000000002c7e0473 21. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x000000002c7dbec3 22. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:0: DB::MergeTreeReadTask::read(DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002c82d05b 23. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:38: DB::MergeTreeThreadSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&, DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002de66094 24. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:0: DB::MergeTreeSelectProcessor::read() @ 0x000000002c8242f9 25. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000002de6d77a 26. ./build_docker/./src/Processors/ISource.cpp:0: DB::ISource::work() @ 0x000000002d3290a1 27. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 28. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 29. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:381: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000002d34bd35 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7eaf0 31. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001af8a79f 2025.09.09 14:54:53.300586 [ 4021 ] {8d3e453c-b14c-4460-8560-bb99fc1b07a7} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=9, jobs=0): (while reading column value): (while reading from part /var/lib/clickhouse/store/3b7/3b7f9237-6979-480e-af74-6371475b2898/all_1_1_0/ in table test_1.num_2 (3b7f9237-6979-480e-af74-6371475b2898) located on disk default of type local, from mark 96 with max_rows_to_read = 57344): While executing MergeTreeSelect(pool: ReadPoolParallelReplicas, algorithm: Thread). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af80b71 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80746 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000266005a2 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000265fffb4 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:1197: ? @ 0x00000000265fd4e7 9. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:62: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x00000000265e6fbd 10. ./contrib/llvm-project/libcxx/include/future:1123: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x00000000265e7bb3 11. DB::ReadBuffer::next() @ 0x000000000b528aeb 12. DB::ReadBuffer::readStrict(char*, unsigned long) @ 0x000000000b581216 13. ./build_docker/./src/Compression/CompressedReadBufferBase.cpp:0: DB::CompressedReadBufferBase::readCompressedData(unsigned long&, unsigned long&, bool) @ 0x000000002775f390 14. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:122: DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x0000000027764cac 15. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:222: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x0000000027ba5430 16. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:0: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x0000000027aa00db 17. ./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) @ 0x000000002c80211e 18. ./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>>&) @ 0x000000002c800e8d 19. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:118: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7c9d8a 20. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x000000002c7e0473 21. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x000000002c7dbec3 22. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:0: DB::MergeTreeReadTask::read(DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002c82d05b 23. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:38: DB::MergeTreeThreadSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&, DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002de66094 24. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:0: DB::MergeTreeSelectProcessor::read() @ 0x000000002c8242f9 25. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000002de6d77a 26. ./build_docker/./src/Processors/ISource.cpp:0: DB::ISource::work() @ 0x000000002d3290a1 27. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 28. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 29. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:381: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000002d34bd35 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7eaf0 31. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001af8a79f 2025.09.09 14:54:53.419679 [ 2688 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 14:54:53.702755 [ 2686 ] {9edbafed-b823-47ff-a2f0-e274c437eae4} executeQuery: Code: 36. DB::Exception: Regexp length too large (2 > 1): In scope SELECT multiMatchAllIndices('123', ['12']). (BAD_ARGUMENTS) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:40996) (comment: 02004_max_hyperscan_regex_length.sql) (in query: select multiMatchAllIndices('123', ['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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&&, unsigned long&) @ 0x000000000e8444da 4. DB::checkHyperscanRegexp(std::vector>, std::allocator>>> const&, unsigned long, unsigned long) @ 0x000000000e843a80 5. DB::FunctionsMultiStringSearch>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015c04c95 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aa8c635 7. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aac91d5 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000cccccfb 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000cccc1ab 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccccc2a 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccce65c 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd2030 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002839a3af 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000028367bce 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028366290 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283b62c9 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002835ae03 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000028359104 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000028357f0d 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002921bdcc 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&) @ 0x000000002941f313 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&) @ 0x0000000029419aef 23. ./contrib/llvm-project/libcxx/include/vector:432: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000029421f5d 24. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000029344c1b 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*) @ 0x0000000029b3703b 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 27. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 28. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 2025.09.09 14:54:53.707437 [ 2686 ] {9edbafed-b823-47ff-a2f0-e274c437eae4} TCPHandler: Code: 36. DB::Exception: Regexp length too large (2 > 1): In scope SELECT multiMatchAllIndices('123', ['12']). (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&&, unsigned long&) @ 0x000000000e8444da 4. DB::checkHyperscanRegexp(std::vector>, std::allocator>>> const&, unsigned long, unsigned long) @ 0x000000000e843a80 5. DB::FunctionsMultiStringSearch>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015c04c95 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aa8c635 7. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aac91d5 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000cccccfb 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000cccc1ab 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccccc2a 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccce65c 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd2030 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002839a3af 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000028367bce 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028366290 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283b62c9 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002835ae03 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000028359104 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000028357f0d 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002921bdcc 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&) @ 0x000000002941f313 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&) @ 0x0000000029419aef 23. ./contrib/llvm-project/libcxx/include/vector:432: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000029421f5d 24. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000029344c1b 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*) @ 0x0000000029b3703b 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 27. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 28. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 2025.09.09 14:54:53.911492 [ 2834 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:54:53.912649 [ 2822 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:54:54.044929 [ 2686 ] {0db68b20-a6d8-4443-95f6-89fbb6950d1d} executeQuery: Code: 36. DB::Exception: Total regexp lengths too large (2 > 1): In scope SELECT multiMatchAllIndices('123', ['1', '2']). (BAD_ARGUMENTS) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:40996) (comment: 02004_max_hyperscan_regex_length.sql) (in query: select multiMatchAllIndices('123', ['1', '2']);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, unsigned long&) @ 0x000000000cf794ba 4. DB::checkHyperscanRegexp(std::vector>, std::allocator>>> const&, unsigned long, unsigned long) @ 0x000000000e843b0a 5. DB::FunctionsMultiStringSearch>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015c04c95 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aa8c635 7. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aac91d5 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000cccccfb 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000cccc1ab 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccccc2a 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccce65c 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd2030 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002839a3af 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000028367bce 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028366290 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283b62c9 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002835ae03 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000028359104 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000028357f0d 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002921bdcc 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&) @ 0x000000002941f313 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&) @ 0x0000000029419aef 23. ./contrib/llvm-project/libcxx/include/vector:432: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000029421f5d 24. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000029344c1b 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*) @ 0x0000000029b3703b 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 27. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 28. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 2025.09.09 14:54:54.054520 [ 2686 ] {0db68b20-a6d8-4443-95f6-89fbb6950d1d} TCPHandler: Code: 36. DB::Exception: Total regexp lengths too large (2 > 1): In scope SELECT multiMatchAllIndices('123', ['1', '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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, unsigned long&) @ 0x000000000cf794ba 4. DB::checkHyperscanRegexp(std::vector>, std::allocator>>> const&, unsigned long, unsigned long) @ 0x000000000e843b0a 5. DB::FunctionsMultiStringSearch>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015c04c95 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aa8c635 7. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aac91d5 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000cccccfb 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000cccc1ab 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccccc2a 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccce65c 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd2030 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002839a3af 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000028367bce 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028366290 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283b62c9 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002835ae03 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000028359104 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000028357f0d 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002921bdcc 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&) @ 0x000000002941f313 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&) @ 0x0000000029419aef 23. ./contrib/llvm-project/libcxx/include/vector:432: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000029421f5d 24. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000029344c1b 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*) @ 0x0000000029b3703b 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 27. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 28. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 2025.09.09 14:54:54.496441 [ 3640 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 14:54:54.525850 [ 2686 ] {319cefe2-7a1e-4d91-8d80-658c4f555f49} executeQuery: Code: 36. DB::Exception: Regexp length too large (2 > 1): In scope SELECT multiFuzzyMatchAny('123', 0, ['12']). (BAD_ARGUMENTS) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:40996) (comment: 02004_max_hyperscan_regex_length.sql) (in query: select multiFuzzyMatchAny('123', 0, ['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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&&, unsigned long&) @ 0x000000000e8444da 4. DB::checkHyperscanRegexp(std::vector>, std::allocator>>> const&, unsigned long, unsigned long) @ 0x000000000e843a80 5. DB::FunctionsMultiStringFuzzySearch>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015bbc30a 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aa8c635 7. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aac91d5 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000cccccfb 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000cccc1ab 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccccc2a 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccce65c 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd2030 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002839a3af 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000028367bce 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028366290 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283b62c9 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002835ae03 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000028359104 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000028357f0d 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002921bdcc 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&) @ 0x000000002941f313 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&) @ 0x0000000029419aef 23. ./contrib/llvm-project/libcxx/include/vector:432: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000029421f5d 24. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000029344c1b 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*) @ 0x0000000029b3703b 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 27. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 28. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 2025.09.09 14:54:54.533326 [ 2686 ] {319cefe2-7a1e-4d91-8d80-658c4f555f49} TCPHandler: Code: 36. DB::Exception: Regexp length too large (2 > 1): In scope SELECT multiFuzzyMatchAny('123', 0, ['12']). (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&&, unsigned long&) @ 0x000000000e8444da 4. DB::checkHyperscanRegexp(std::vector>, std::allocator>>> const&, unsigned long, unsigned long) @ 0x000000000e843a80 5. DB::FunctionsMultiStringFuzzySearch>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015bbc30a 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aa8c635 7. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aac91d5 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000cccccfb 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000cccc1ab 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccccc2a 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccce65c 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd2030 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002839a3af 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000028367bce 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028366290 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283b62c9 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002835ae03 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000028359104 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000028357f0d 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002921bdcc 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&) @ 0x000000002941f313 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&) @ 0x0000000029419aef 23. ./contrib/llvm-project/libcxx/include/vector:432: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000029421f5d 24. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000029344c1b 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*) @ 0x0000000029b3703b 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 27. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 28. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 2025.09.09 14:54:54.607612 [ 4021 ] {d3b29712-fd2d-4deb-95e4-aa4197ba500f} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=7, jobs=7). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:43268) (comment: 02967_parallel_replicas_join_algo_and_analyzer_3.sh) (in query: SELECT `__table1`.`key` AS `key`, `__table1`.`value` AS `value` FROM `test_1`.`num_2` AS `__table1` GLOBAL ALL INNER JOIN `_data_6159103449907252772_9558241464499801717` AS `__table2` ON `__table1`.`key` = `__table2`.`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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af80b71 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80746 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d34b5ca 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:306: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349fbb 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:381: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000002d34bd35 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7eaf0 10. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001af8a79f 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 13. asan_thread_start(void*) @ 0x000000000aa43059 14. ? @ 0x00007f35aab92ac3 15. ? @ 0x00007f35aac24850 2025.09.09 14:54:54.613827 [ 4021 ] {d3b29712-fd2d-4deb-95e4-aa4197ba500f} 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af80b71 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80746 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d34b5ca 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:306: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349fbb 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:381: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000002d34bd35 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7eaf0 10. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001af8a79f 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 13. asan_thread_start(void*) @ 0x000000000aa43059 14. ? @ 0x00007f35aab92ac3 15. ? @ 0x00007f35aac24850 2025.09.09 14:54:54.768740 [ 2688 ] {4ac62ee1-9de4-4254-ba6c-5779622bd41d} executeQuery: Code: 439. DB::Exception: Received from 127.0.0.2:9000. DB::Exception: Cannot schedule a task: fault injected (threads=7, jobs=7). Stack trace: 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af80b71 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80746 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d34b5ca 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:306: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349fbb 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:381: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000002d34bd35 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7eaf0 10. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001af8a79f 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 13. asan_thread_start(void*) @ 0x000000000aa43059 14. ? @ 0x00007f35aab92ac3 15. ? @ 0x00007f35aac24850 : While executing Remote. (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:41028) (comment: 02967_parallel_replicas_join_algo_and_analyzer_3.sh) (in query: select * from (select key, value from num_1) l inner join (select key, value from num_2 inner join (select number * 7 as key from numbers(1e5)) as nn on num_2.key = nn.key settings join_algorithm='hash') r on l.key = r.key order by l.key limit 10 offset 10000 SETTINGS enable_analyzer=1, enable_parallel_replicas = 2, max_parallel_replicas = 2, parallel_replicas_for_non_replicated_merge_tree = 1, cluster_for_parallel_replicas = 'test_cluster_one_shard_three_replicas_localhost', parallel_replicas_local_plan=1, parallel_replicas_prefer_local_join=0, send_logs_level='trace', 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. ./contrib/llvm-project/libcxx/include/string:1499: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x000000001aeb974e 3. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::Connection::receiveException() const @ 0x000000002cee6c6a 4. ./build_docker/./src/Client/Connection.cpp:0: DB::Connection::receivePacket() @ 0x000000002cef780e 5. ./build_docker/./src/Client/MultiplexedConnections.cpp:340: DB::MultiplexedConnections::receivePacketUnlocked(std::function) @ 0x000000002cf8e09e 6. ./build_docker/./src/QueryPipeline/RemoteQueryExecutorReadContext.cpp:0: DB::RemoteQueryExecutorReadContext::Task::run(std::function, std::function) @ 0x00000000278ad616 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000278ab436 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000278aaa44 9. ./contrib/boost/boost/context/fiber_ucontext.hpp:82: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x00000000278a8394 2025.09.09 14:54:54.742130 [ 2686 ] {0ff936f6-47a0-4234-a4f2-65f1f8e071d4} executeQuery: Code: 36. DB::Exception: Total regexp lengths too large (2 > 1): In scope SELECT multiFuzzyMatchAny('123', 0, ['1', '2']). (BAD_ARGUMENTS) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:40996) (comment: 02004_max_hyperscan_regex_length.sql) (in query: select multiFuzzyMatchAny('123', 0, ['1', '2']);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, unsigned long&) @ 0x000000000cf794ba 4. DB::checkHyperscanRegexp(std::vector>, std::allocator>>> const&, unsigned long, unsigned long) @ 0x000000000e843b0a 5. DB::FunctionsMultiStringFuzzySearch>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015bbc30a 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aa8c635 7. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aac91d5 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000cccccfb 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000cccc1ab 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccccc2a 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccce65c 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd2030 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002839a3af 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000028367bce 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028366290 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283b62c9 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002835ae03 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000028359104 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000028357f0d 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002921bdcc 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&) @ 0x000000002941f313 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&) @ 0x0000000029419aef 23. ./contrib/llvm-project/libcxx/include/vector:432: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000029421f5d 24. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000029344c1b 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*) @ 0x0000000029b3703b 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 27. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 28. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 2025.09.09 14:54:54.801299 [ 2686 ] {0ff936f6-47a0-4234-a4f2-65f1f8e071d4} TCPHandler: Code: 36. DB::Exception: Total regexp lengths too large (2 > 1): In scope SELECT multiFuzzyMatchAny('123', 0, ['1', '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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, unsigned long&) @ 0x000000000cf794ba 4. DB::checkHyperscanRegexp(std::vector>, std::allocator>>> const&, unsigned long, unsigned long) @ 0x000000000e843b0a 5. DB::FunctionsMultiStringFuzzySearch>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015bbc30a 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aa8c635 7. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aac91d5 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000cccccfb 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000cccc1ab 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccccc2a 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccce65c 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd2030 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002839a3af 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000028367bce 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028366290 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283b62c9 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002835ae03 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000028359104 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000028357f0d 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002921bdcc 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&) @ 0x000000002941f313 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&) @ 0x0000000029419aef 23. ./contrib/llvm-project/libcxx/include/vector:432: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000029421f5d 24. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000029344c1b 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*) @ 0x0000000029b3703b 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 27. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 28. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 2025.09.09 14:54:54.815767 [ 2688 ] {4ac62ee1-9de4-4254-ba6c-5779622bd41d} TCPHandler: Code: 439. DB::Exception: Received from 127.0.0.2:9000. DB::Exception: Cannot schedule a task: fault injected (threads=7, jobs=7). Stack trace: 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af80b71 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80746 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d34b5ca 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:306: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349fbb 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:381: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000002d34bd35 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7eaf0 10. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001af8a79f 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 13. asan_thread_start(void*) @ 0x000000000aa43059 14. ? @ 0x00007f35aab92ac3 15. ? @ 0x00007f35aac24850 : 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. ./contrib/llvm-project/libcxx/include/string:1499: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x000000001aeb974e 3. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::Connection::receiveException() const @ 0x000000002cee6c6a 4. ./build_docker/./src/Client/Connection.cpp:0: DB::Connection::receivePacket() @ 0x000000002cef780e 5. ./build_docker/./src/Client/MultiplexedConnections.cpp:340: DB::MultiplexedConnections::receivePacketUnlocked(std::function) @ 0x000000002cf8e09e 6. ./build_docker/./src/QueryPipeline/RemoteQueryExecutorReadContext.cpp:0: DB::RemoteQueryExecutorReadContext::Task::run(std::function, std::function) @ 0x00000000278ad616 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000278ab436 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000278aaa44 9. ./contrib/boost/boost/context/fiber_ucontext.hpp:82: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x00000000278a8394 2025.09.09 14:54:54.913756 [ 2858 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:54:54.914768 [ 2861 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:54:55.308809 [ 2686 ] {607731f5-c7b8-468b-b2b5-394357908923} executeQuery: Code: 36. DB::Exception: Regexp length too large (2 > 1): In scope SELECT multiFuzzyMatchAnyIndex('123', 0, ['12']). (BAD_ARGUMENTS) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:40996) (comment: 02004_max_hyperscan_regex_length.sql) (in query: select multiFuzzyMatchAnyIndex('123', 0, ['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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&&, unsigned long&) @ 0x000000000e8444da 4. DB::checkHyperscanRegexp(std::vector>, std::allocator>>> const&, unsigned long, unsigned long) @ 0x000000000e843a80 5. DB::FunctionsMultiStringFuzzySearch>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015bc4002 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aa8c635 7. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aac91d5 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000cccccfb 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000cccc1ab 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccccc2a 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccce65c 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd2030 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002839a3af 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000028367bce 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028366290 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283b62c9 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002835ae03 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000028359104 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000028357f0d 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002921bdcc 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&) @ 0x000000002941f313 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&) @ 0x0000000029419aef 23. ./contrib/llvm-project/libcxx/include/vector:432: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000029421f5d 24. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000029344c1b 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*) @ 0x0000000029b3703b 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 27. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 28. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 2025.09.09 14:54:55.314422 [ 2686 ] {607731f5-c7b8-468b-b2b5-394357908923} TCPHandler: Code: 36. DB::Exception: Regexp length too large (2 > 1): In scope SELECT multiFuzzyMatchAnyIndex('123', 0, ['12']). (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&&, unsigned long&) @ 0x000000000e8444da 4. DB::checkHyperscanRegexp(std::vector>, std::allocator>>> const&, unsigned long, unsigned long) @ 0x000000000e843a80 5. DB::FunctionsMultiStringFuzzySearch>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015bc4002 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aa8c635 7. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aac91d5 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000cccccfb 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000cccc1ab 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccccc2a 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccce65c 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd2030 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002839a3af 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000028367bce 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028366290 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283b62c9 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002835ae03 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000028359104 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000028357f0d 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002921bdcc 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&) @ 0x000000002941f313 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&) @ 0x0000000029419aef 23. ./contrib/llvm-project/libcxx/include/vector:432: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000029421f5d 24. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000029344c1b 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*) @ 0x0000000029b3703b 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 27. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 28. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 2025.09.09 14:54:55.481470 [ 2686 ] {d6e214be-d200-4856-932f-37e78cda9a92} executeQuery: Code: 36. DB::Exception: Total regexp lengths too large (2 > 1): In scope SELECT multiFuzzyMatchAnyIndex('123', 0, ['1', '2']). (BAD_ARGUMENTS) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:40996) (comment: 02004_max_hyperscan_regex_length.sql) (in query: select multiFuzzyMatchAnyIndex('123', 0, ['1', '2']);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, unsigned long&) @ 0x000000000cf794ba 4. DB::checkHyperscanRegexp(std::vector>, std::allocator>>> const&, unsigned long, unsigned long) @ 0x000000000e843b0a 5. DB::FunctionsMultiStringFuzzySearch>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015bc4002 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aa8c635 7. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aac91d5 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000cccccfb 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000cccc1ab 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccccc2a 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccce65c 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd2030 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002839a3af 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000028367bce 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028366290 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283b62c9 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002835ae03 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000028359104 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000028357f0d 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002921bdcc 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&) @ 0x000000002941f313 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&) @ 0x0000000029419aef 23. ./contrib/llvm-project/libcxx/include/vector:432: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000029421f5d 24. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000029344c1b 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*) @ 0x0000000029b3703b 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 27. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 28. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 2025.09.09 14:54:55.486355 [ 2686 ] {d6e214be-d200-4856-932f-37e78cda9a92} TCPHandler: Code: 36. DB::Exception: Total regexp lengths too large (2 > 1): In scope SELECT multiFuzzyMatchAnyIndex('123', 0, ['1', '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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, unsigned long&) @ 0x000000000cf794ba 4. DB::checkHyperscanRegexp(std::vector>, std::allocator>>> const&, unsigned long, unsigned long) @ 0x000000000e843b0a 5. DB::FunctionsMultiStringFuzzySearch>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015bc4002 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aa8c635 7. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aac91d5 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000cccccfb 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000cccc1ab 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccccc2a 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccce65c 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd2030 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002839a3af 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000028367bce 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028366290 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283b62c9 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002835ae03 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000028359104 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000028357f0d 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002921bdcc 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&) @ 0x000000002941f313 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&) @ 0x0000000029419aef 23. ./contrib/llvm-project/libcxx/include/vector:432: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000029421f5d 24. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000029344c1b 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*) @ 0x0000000029b3703b 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 27. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 28. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 2025.09.09 14:54:55.503158 [ 4021 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 14:54:55.827616 [ 2686 ] {6d2769a8-8857-4fd2-8975-7055badd0e41} executeQuery: Code: 36. DB::Exception: Regexp length too large (2 > 1): In scope SELECT multiFuzzyMatchAllIndices('123', 0, ['12']). (BAD_ARGUMENTS) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:40996) (comment: 02004_max_hyperscan_regex_length.sql) (in query: select multiFuzzyMatchAllIndices('123', 0, ['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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&&, unsigned long&) @ 0x000000000e8444da 4. DB::checkHyperscanRegexp(std::vector>, std::allocator>>> const&, unsigned long, unsigned long) @ 0x000000000e843a80 5. DB::FunctionsMultiStringFuzzySearch>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015bb1410 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aa8c635 7. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aac91d5 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000cccccfb 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000cccc1ab 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccccc2a 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccce65c 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd2030 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002839a3af 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000028367bce 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028366290 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283b62c9 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002835ae03 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000028359104 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000028357f0d 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002921bdcc 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&) @ 0x000000002941f313 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&) @ 0x0000000029419aef 23. ./contrib/llvm-project/libcxx/include/vector:432: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000029421f5d 24. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000029344c1b 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*) @ 0x0000000029b3703b 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 27. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 28. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 2025.09.09 14:54:55.832294 [ 2686 ] {6d2769a8-8857-4fd2-8975-7055badd0e41} TCPHandler: Code: 36. DB::Exception: Regexp length too large (2 > 1): In scope SELECT multiFuzzyMatchAllIndices('123', 0, ['12']). (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&&, unsigned long&) @ 0x000000000e8444da 4. DB::checkHyperscanRegexp(std::vector>, std::allocator>>> const&, unsigned long, unsigned long) @ 0x000000000e843a80 5. DB::FunctionsMultiStringFuzzySearch>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015bb1410 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aa8c635 7. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aac91d5 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000cccccfb 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000cccc1ab 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccccc2a 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccce65c 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd2030 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002839a3af 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000028367bce 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028366290 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283b62c9 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002835ae03 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000028359104 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000028357f0d 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002921bdcc 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&) @ 0x000000002941f313 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&) @ 0x0000000029419aef 23. ./contrib/llvm-project/libcxx/include/vector:432: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000029421f5d 24. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000029344c1b 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*) @ 0x0000000029b3703b 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 27. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 28. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 2025.09.09 14:54:55.915542 [ 2871 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:54:55.916731 [ 2880 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:54:55.995141 [ 2686 ] {530b43bc-c566-4055-8498-56fa10959e13} executeQuery: Code: 36. DB::Exception: Total regexp lengths too large (2 > 1): In scope SELECT multiFuzzyMatchAllIndices('123', 0, ['1', '2']). (BAD_ARGUMENTS) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:40996) (comment: 02004_max_hyperscan_regex_length.sql) (in query: select multiFuzzyMatchAllIndices('123', 0, ['1', '2']);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, unsigned long&) @ 0x000000000cf794ba 4. DB::checkHyperscanRegexp(std::vector>, std::allocator>>> const&, unsigned long, unsigned long) @ 0x000000000e843b0a 5. DB::FunctionsMultiStringFuzzySearch>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015bb1410 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aa8c635 7. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aac91d5 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000cccccfb 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000cccc1ab 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccccc2a 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccce65c 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd2030 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002839a3af 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000028367bce 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028366290 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283b62c9 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002835ae03 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000028359104 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000028357f0d 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002921bdcc 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&) @ 0x000000002941f313 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&) @ 0x0000000029419aef 23. ./contrib/llvm-project/libcxx/include/vector:432: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000029421f5d 24. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000029344c1b 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*) @ 0x0000000029b3703b 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 27. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 28. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 2025.09.09 14:54:56.001485 [ 2686 ] {530b43bc-c566-4055-8498-56fa10959e13} TCPHandler: Code: 36. DB::Exception: Total regexp lengths too large (2 > 1): In scope SELECT multiFuzzyMatchAllIndices('123', 0, ['1', '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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, unsigned long&) @ 0x000000000cf794ba 4. DB::checkHyperscanRegexp(std::vector>, std::allocator>>> const&, unsigned long, unsigned long) @ 0x000000000e843b0a 5. DB::FunctionsMultiStringFuzzySearch>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015bb1410 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aa8c635 7. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aac91d5 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000cccccfb 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000cccc1ab 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccccc2a 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccce65c 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd2030 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002839a3af 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000028367bce 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028366290 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283b62c9 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002835ae03 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000028359104 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000028357f0d 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002921bdcc 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&) @ 0x000000002941f313 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&) @ 0x0000000029419aef 23. ./contrib/llvm-project/libcxx/include/vector:432: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000029421f5d 24. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000029344c1b 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*) @ 0x0000000029b3703b 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 27. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 28. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 2025.09.09 14:54:56.023783 [ 4021 ] {0e0963a8-689c-4983-997d-c66e4e8d4847} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=4, jobs=4). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:43272) (comment: 02967_parallel_replicas_join_algo_and_analyzer_3.sh) (in query: SELECT `__table1`.`key` AS `key`, `__table1`.`value` AS `value` FROM `test_1`.`num_2` AS `__table1` GLOBAL ALL INNER JOIN `_data_6159103449907252772_9558241464499801717` AS `__table2` ON `__table1`.`key` = `__table2`.`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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af819ed 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80746 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d34b5ca 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000002d3486e4 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000002d34827b 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002d36bcf7 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 12. asan_thread_start(void*) @ 0x000000000aa43059 13. ? @ 0x00007f35aab92ac3 14. ? @ 0x00007f35aac24850 2025.09.09 14:54:56.035059 [ 4021 ] {0e0963a8-689c-4983-997d-c66e4e8d4847} TCPHandler: 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af819ed 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80746 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d34b5ca 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000002d3486e4 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000002d34827b 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002d36bcf7 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 12. asan_thread_start(void*) @ 0x000000000aa43059 13. ? @ 0x00007f35aab92ac3 14. ? @ 0x00007f35aac24850 2025.09.09 14:54:56.064971 [ 2688 ] {b1ce0405-19a9-4f75-a386-b07f71b70f9b} executeQuery: Code: 439. DB::Exception: Received from 127.0.0.2:9000. DB::Exception: Cannot schedule a task: failed to start the thread (threads=4, jobs=4). Stack trace: 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af819ed 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80746 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d34b5ca 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000002d3486e4 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000002d34827b 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002d36bcf7 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 12. asan_thread_start(void*) @ 0x000000000aa43059 13. ? @ 0x00007f35aab92ac3 14. ? @ 0x00007f35aac24850 : While executing Remote. (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:41034) (comment: 02967_parallel_replicas_join_algo_and_analyzer_3.sh) (in query: select * from (select key, value from num_1) l inner join (select key, value from num_2 inner join (select number * 7 as key from numbers(1e5)) as nn on num_2.key = nn.key settings join_algorithm='full_sorting_merge') r on l.key = r.key order by l.key limit 10 offset 10000 SETTINGS enable_analyzer=1, enable_parallel_replicas = 2, max_parallel_replicas = 2, parallel_replicas_for_non_replicated_merge_tree = 1, cluster_for_parallel_replicas = 'test_cluster_one_shard_three_replicas_localhost', parallel_replicas_local_plan=1, parallel_replicas_prefer_local_join=0, join_algorithm='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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. ./contrib/llvm-project/libcxx/include/string:1499: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x000000001aeb974e 3. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::Connection::receiveException() const @ 0x000000002cee6c6a 4. ./build_docker/./src/Client/Connection.cpp:0: DB::Connection::receivePacket() @ 0x000000002cef780e 5. ./build_docker/./src/Client/MultiplexedConnections.cpp:340: DB::MultiplexedConnections::receivePacketUnlocked(std::function) @ 0x000000002cf8e09e 6. ./build_docker/./src/QueryPipeline/RemoteQueryExecutorReadContext.cpp:0: DB::RemoteQueryExecutorReadContext::Task::run(std::function, std::function) @ 0x00000000278ad616 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000278ab436 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000278aaa44 9. ./contrib/boost/boost/context/fiber_ucontext.hpp:82: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x00000000278a8394 2025.09.09 14:54:56.077923 [ 2688 ] {b1ce0405-19a9-4f75-a386-b07f71b70f9b} TCPHandler: Code: 439. DB::Exception: Received from 127.0.0.2:9000. DB::Exception: Cannot schedule a task: failed to start the thread (threads=4, jobs=4). Stack trace: 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af819ed 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80746 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d34b5ca 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000002d3486e4 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000002d34827b 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002d36bcf7 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 12. asan_thread_start(void*) @ 0x000000000aa43059 13. ? @ 0x00007f35aab92ac3 14. ? @ 0x00007f35aac24850 : 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. ./contrib/llvm-project/libcxx/include/string:1499: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x000000001aeb974e 3. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::Connection::receiveException() const @ 0x000000002cee6c6a 4. ./build_docker/./src/Client/Connection.cpp:0: DB::Connection::receivePacket() @ 0x000000002cef780e 5. ./build_docker/./src/Client/MultiplexedConnections.cpp:340: DB::MultiplexedConnections::receivePacketUnlocked(std::function) @ 0x000000002cf8e09e 6. ./build_docker/./src/QueryPipeline/RemoteQueryExecutorReadContext.cpp:0: DB::RemoteQueryExecutorReadContext::Task::run(std::function, std::function) @ 0x00000000278ad616 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000278ab436 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000278aaa44 9. ./contrib/boost/boost/context/fiber_ucontext.hpp:82: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x00000000278a8394 2025.09.09 14:54:56.280925 [ 3612 ] {} DynamicQueryHandler: Code: 452. DB::Exception: Setting max_execution_time shouldn't be greater than 60. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x0000000026f841fa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:368: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f81de0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/find_if.h:25: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f808a4 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000002d065739 10. ./build_docker/./src/Server/HTTPHandler.cpp:705: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000002d06d139 11. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000002d1cc337 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 15. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 16. asan_thread_start(void*) @ 0x000000000aa43059 17. ? @ 0x00007f35aab92ac3 18. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:54:56.547472 [ 2686 ] {ce705acf-2fe6-479c-8dd1-5cf30f8fb963} executeQuery: Code: 36. DB::Exception: Regexp length too large (2 > 1): while executing 'FUNCTION multiMatchAny(materialize('123'_String) :: 3, materialize(_CAST(['12']_Array(String), 'Array(String)'_String)) :: 1) -> multiMatchAny(materialize('123'_String), materialize(_CAST(['12']_Array(String), 'Array(String)'_String))) UInt8 : 2'. (BAD_ARGUMENTS) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:40996) (comment: 02004_max_hyperscan_regex_length.sql) (in query: select multiMatchAny(materialize('123'), materialize(['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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&&, unsigned long&) @ 0x000000000e8444da 4. DB::checkHyperscanRegexp(std::vector>, std::allocator>>> const&, unsigned long, unsigned long) @ 0x000000000e843a80 5. DB::FunctionsMultiStringSearch>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015c0beca 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aac9135 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000cccce5b 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccce65c 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd2030 10. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x00000000286fc2bd 11. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000002d9c29ae 12. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 13. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 14. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000002d34877c 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000002d34827b 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*) @ 0x000000002d36bcf7 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 21. asan_thread_start(void*) @ 0x000000000aa43059 22. ? @ 0x00007f35aab92ac3 23. ? @ 0x00007f35aac24850 2025.09.09 14:54:56.549122 [ 4021 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 14:54:56.549608 [ 2686 ] {ce705acf-2fe6-479c-8dd1-5cf30f8fb963} TCPHandler: Code: 36. DB::Exception: Regexp length too large (2 > 1): while executing 'FUNCTION multiMatchAny(materialize('123'_String) :: 3, materialize(_CAST(['12']_Array(String), 'Array(String)'_String)) :: 1) -> multiMatchAny(materialize('123'_String), materialize(_CAST(['12']_Array(String), 'Array(String)'_String))) UInt8 : 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&&, unsigned long&) @ 0x000000000e8444da 4. DB::checkHyperscanRegexp(std::vector>, std::allocator>>> const&, unsigned long, unsigned long) @ 0x000000000e843a80 5. DB::FunctionsMultiStringSearch>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015c0beca 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aac9135 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000cccce5b 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccce65c 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd2030 10. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x00000000286fc2bd 11. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000002d9c29ae 12. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 13. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 14. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000002d34877c 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000002d34827b 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*) @ 0x000000002d36bcf7 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 21. asan_thread_start(void*) @ 0x000000000aa43059 22. ? @ 0x00007f35aab92ac3 23. ? @ 0x00007f35aac24850 2025.09.09 14:54:56.764625 [ 2686 ] {98af99ab-ed3b-4a06-91af-9e994de383af} executeQuery: Code: 36. DB::Exception: Total regexp lengths too large (2 > 1): while executing 'FUNCTION multiMatchAny(materialize('123'_String) :: 3, materialize(_CAST(['1', '2']_Array(String), 'Array(String)'_String)) :: 1) -> multiMatchAny(materialize('123'_String), materialize(_CAST(['1', '2']_Array(String), 'Array(String)'_String))) UInt8 : 2'. (BAD_ARGUMENTS) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:40996) (comment: 02004_max_hyperscan_regex_length.sql) (in query: select multiMatchAny(materialize('123'), materialize(['1', '2']));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, unsigned long&) @ 0x000000000cf794ba 4. DB::checkHyperscanRegexp(std::vector>, std::allocator>>> const&, unsigned long, unsigned long) @ 0x000000000e843b0a 5. DB::FunctionsMultiStringSearch>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015c0beca 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aac9135 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000cccce5b 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccce65c 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd2030 10. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x00000000286fc2bd 11. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000002d9c29ae 12. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 13. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 14. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000002d34877c 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000002d34827b 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*) @ 0x000000002d36bcf7 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 21. asan_thread_start(void*) @ 0x000000000aa43059 22. ? @ 0x00007f35aab92ac3 23. ? @ 0x00007f35aac24850 2025.09.09 14:54:56.766653 [ 2686 ] {98af99ab-ed3b-4a06-91af-9e994de383af} TCPHandler: Code: 36. DB::Exception: Total regexp lengths too large (2 > 1): while executing 'FUNCTION multiMatchAny(materialize('123'_String) :: 3, materialize(_CAST(['1', '2']_Array(String), 'Array(String)'_String)) :: 1) -> multiMatchAny(materialize('123'_String), materialize(_CAST(['1', '2']_Array(String), 'Array(String)'_String))) UInt8 : 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, unsigned long&) @ 0x000000000cf794ba 4. DB::checkHyperscanRegexp(std::vector>, std::allocator>>> const&, unsigned long, unsigned long) @ 0x000000000e843b0a 5. DB::FunctionsMultiStringSearch>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015c0beca 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aac9135 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000cccce5b 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccce65c 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd2030 10. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x00000000286fc2bd 11. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000002d9c29ae 12. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 13. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 14. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000002d34877c 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000002d34827b 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*) @ 0x000000002d36bcf7 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 21. asan_thread_start(void*) @ 0x000000000aa43059 22. ? @ 0x00007f35aab92ac3 23. ? @ 0x00007f35aac24850 2025.09.09 14:54:56.918209 [ 2894 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:54:56.918906 [ 2907 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:54:56.971076 [ 2686 ] {14609dee-3168-4b10-8ca5-79c36fefa25e} executeQuery: Code: 36. DB::Exception: Regexp length too large (2 > 1): while executing 'FUNCTION multiMatchAnyIndex(materialize('123'_String) :: 3, materialize(_CAST(['12']_Array(String), 'Array(String)'_String)) :: 1) -> multiMatchAnyIndex(materialize('123'_String), materialize(_CAST(['12']_Array(String), 'Array(String)'_String))) UInt64 : 2'. (BAD_ARGUMENTS) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:40996) (comment: 02004_max_hyperscan_regex_length.sql) (in query: select multiMatchAnyIndex(materialize('123'), materialize(['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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&&, unsigned long&) @ 0x000000000e8444da 4. DB::checkHyperscanRegexp(std::vector>, std::allocator>>> const&, unsigned long, unsigned long) @ 0x000000000e843a80 5. DB::FunctionsMultiStringSearch>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015c1292e 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aac9135 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000cccce5b 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccce65c 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd2030 10. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x00000000286fc2bd 11. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000002d9c29ae 12. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 13. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 14. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000002d34877c 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000002d34827b 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*) @ 0x000000002d36bcf7 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 21. asan_thread_start(void*) @ 0x000000000aa43059 22. ? @ 0x00007f35aab92ac3 23. ? @ 0x00007f35aac24850 2025.09.09 14:54:56.973925 [ 2686 ] {14609dee-3168-4b10-8ca5-79c36fefa25e} TCPHandler: Code: 36. DB::Exception: Regexp length too large (2 > 1): while executing 'FUNCTION multiMatchAnyIndex(materialize('123'_String) :: 3, materialize(_CAST(['12']_Array(String), 'Array(String)'_String)) :: 1) -> multiMatchAnyIndex(materialize('123'_String), materialize(_CAST(['12']_Array(String), 'Array(String)'_String))) UInt64 : 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&&, unsigned long&) @ 0x000000000e8444da 4. DB::checkHyperscanRegexp(std::vector>, std::allocator>>> const&, unsigned long, unsigned long) @ 0x000000000e843a80 5. DB::FunctionsMultiStringSearch>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015c1292e 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aac9135 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000cccce5b 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccce65c 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd2030 10. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x00000000286fc2bd 11. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000002d9c29ae 12. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 13. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 14. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000002d34877c 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000002d34827b 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*) @ 0x000000002d36bcf7 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 21. asan_thread_start(void*) @ 0x000000000aa43059 22. ? @ 0x00007f35aab92ac3 23. ? @ 0x00007f35aac24850 2025.09.09 14:54:57.039547 [ 4021 ] {29c819b8-5b61-42b2-bcd5-34d38071f9f3} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=4, jobs=4). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:56814) (comment: 02967_parallel_replicas_join_algo_and_analyzer_3.sh) (in query: SELECT `__table1`.`key` AS `key`, `__table1`.`value` AS `value` FROM `test_1`.`num_2` AS `__table1` GLOBAL ALL INNER JOIN `_data_6159103449907252772_9558241464499801717` AS `__table2` ON `__table1`.`key` = `__table2`.`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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af819ed 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80746 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d34b5ca 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000002d3486e4 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000002d34827b 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002d36bcf7 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 12. asan_thread_start(void*) @ 0x000000000aa43059 13. ? @ 0x00007f35aab92ac3 14. ? @ 0x00007f35aac24850 2025.09.09 14:54:57.043764 [ 4021 ] {29c819b8-5b61-42b2-bcd5-34d38071f9f3} TCPHandler: 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af819ed 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80746 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d34b5ca 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000002d3486e4 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000002d34827b 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002d36bcf7 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 12. asan_thread_start(void*) @ 0x000000000aa43059 13. ? @ 0x00007f35aab92ac3 14. ? @ 0x00007f35aac24850 2025.09.09 14:54:57.072158 [ 2686 ] {7af64b4f-64bf-4597-b8ea-ae926c7235ed} executeQuery: Code: 36. DB::Exception: Total regexp lengths too large (2 > 1): while executing 'FUNCTION multiMatchAnyIndex(materialize('123'_String) :: 3, materialize(_CAST(['1', '2']_Array(String), 'Array(String)'_String)) :: 1) -> multiMatchAnyIndex(materialize('123'_String), materialize(_CAST(['1', '2']_Array(String), 'Array(String)'_String))) UInt64 : 2'. (BAD_ARGUMENTS) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:40996) (comment: 02004_max_hyperscan_regex_length.sql) (in query: select multiMatchAnyIndex(materialize('123'), materialize(['1', '2']));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, unsigned long&) @ 0x000000000cf794ba 4. DB::checkHyperscanRegexp(std::vector>, std::allocator>>> const&, unsigned long, unsigned long) @ 0x000000000e843b0a 5. DB::FunctionsMultiStringSearch>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015c1292e 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aac9135 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000cccce5b 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccce65c 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd2030 10. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x00000000286fc2bd 11. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000002d9c29ae 12. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 13. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 14. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000002d34877c 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000002d34827b 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*) @ 0x000000002d36bcf7 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 21. asan_thread_start(void*) @ 0x000000000aa43059 22. ? @ 0x00007f35aab92ac3 23. ? @ 0x00007f35aac24850 2025.09.09 14:54:57.074338 [ 2686 ] {7af64b4f-64bf-4597-b8ea-ae926c7235ed} TCPHandler: Code: 36. DB::Exception: Total regexp lengths too large (2 > 1): while executing 'FUNCTION multiMatchAnyIndex(materialize('123'_String) :: 3, materialize(_CAST(['1', '2']_Array(String), 'Array(String)'_String)) :: 1) -> multiMatchAnyIndex(materialize('123'_String), materialize(_CAST(['1', '2']_Array(String), 'Array(String)'_String))) UInt64 : 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, unsigned long&) @ 0x000000000cf794ba 4. DB::checkHyperscanRegexp(std::vector>, std::allocator>>> const&, unsigned long, unsigned long) @ 0x000000000e843b0a 5. DB::FunctionsMultiStringSearch>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015c1292e 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aac9135 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000cccce5b 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccce65c 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd2030 10. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x00000000286fc2bd 11. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000002d9c29ae 12. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 13. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 14. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000002d34877c 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000002d34827b 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*) @ 0x000000002d36bcf7 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 21. asan_thread_start(void*) @ 0x000000000aa43059 22. ? @ 0x00007f35aab92ac3 23. ? @ 0x00007f35aac24850 2025.09.09 14:54:57.128281 [ 2688 ] {959e0310-3c7b-470b-b916-f309991cd652} executeQuery: Code: 439. DB::Exception: Received from 127.0.0.3:9000. DB::Exception: Cannot schedule a task: failed to start the thread (threads=4, jobs=4). Stack trace: 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af819ed 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80746 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d34b5ca 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000002d3486e4 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000002d34827b 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002d36bcf7 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 12. asan_thread_start(void*) @ 0x000000000aa43059 13. ? @ 0x00007f35aab92ac3 14. ? @ 0x00007f35aac24850 : While executing Remote. (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:41042) (comment: 02967_parallel_replicas_join_algo_and_analyzer_3.sh) (in query: select * from (select key, value from num_1) l inner join (select key, value from num_2 inner join (select number * 7 as key from numbers(1e5)) as nn on num_2.key = nn.key settings join_algorithm='full_sorting_merge') r on l.key = r.key order by l.key limit 10 offset 10000 SETTINGS enable_analyzer=1, enable_parallel_replicas = 2, max_parallel_replicas = 2, parallel_replicas_for_non_replicated_merge_tree = 1, cluster_for_parallel_replicas = 'test_cluster_one_shard_three_replicas_localhost', parallel_replicas_local_plan=1, parallel_replicas_prefer_local_join=0, send_logs_level='trace', join_algorithm='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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. ./contrib/llvm-project/libcxx/include/string:1499: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x000000001aeb974e 3. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::Connection::receiveException() const @ 0x000000002cee6c6a 4. ./build_docker/./src/Client/Connection.cpp:0: DB::Connection::receivePacket() @ 0x000000002cef780e 5. ./build_docker/./src/Client/MultiplexedConnections.cpp:340: DB::MultiplexedConnections::receivePacketUnlocked(std::function) @ 0x000000002cf8e09e 6. ./build_docker/./src/QueryPipeline/RemoteQueryExecutorReadContext.cpp:0: DB::RemoteQueryExecutorReadContext::Task::run(std::function, std::function) @ 0x00000000278ad616 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000278ab436 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000278aaa44 9. ./contrib/boost/boost/context/fiber_ucontext.hpp:82: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x00000000278a8394 2025.09.09 14:54:57.140641 [ 2688 ] {959e0310-3c7b-470b-b916-f309991cd652} TCPHandler: Code: 439. DB::Exception: Received from 127.0.0.3:9000. DB::Exception: Cannot schedule a task: failed to start the thread (threads=4, jobs=4). Stack trace: 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af819ed 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80746 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d34b5ca 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000002d3486e4 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000002d34827b 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002d36bcf7 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 12. asan_thread_start(void*) @ 0x000000000aa43059 13. ? @ 0x00007f35aab92ac3 14. ? @ 0x00007f35aac24850 : 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. ./contrib/llvm-project/libcxx/include/string:1499: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x000000001aeb974e 3. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::Connection::receiveException() const @ 0x000000002cee6c6a 4. ./build_docker/./src/Client/Connection.cpp:0: DB::Connection::receivePacket() @ 0x000000002cef780e 5. ./build_docker/./src/Client/MultiplexedConnections.cpp:340: DB::MultiplexedConnections::receivePacketUnlocked(std::function) @ 0x000000002cf8e09e 6. ./build_docker/./src/QueryPipeline/RemoteQueryExecutorReadContext.cpp:0: DB::RemoteQueryExecutorReadContext::Task::run(std::function, std::function) @ 0x00000000278ad616 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000278ab436 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000278aaa44 9. ./contrib/boost/boost/context/fiber_ucontext.hpp:82: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x00000000278a8394 2025.09.09 14:54:57.498280 [ 2686 ] {1d0eb7ea-af20-4bd9-a062-6cc58e93dcc5} executeQuery: Code: 36. DB::Exception: Regexp length too large (2 > 1): while executing 'FUNCTION multiMatchAllIndices(materialize('123'_String) :: 3, materialize(_CAST(['12']_Array(String), 'Array(String)'_String)) :: 1) -> multiMatchAllIndices(materialize('123'_String), materialize(_CAST(['12']_Array(String), 'Array(String)'_String))) Array(UInt64) : 2'. (BAD_ARGUMENTS) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:40996) (comment: 02004_max_hyperscan_regex_length.sql) (in query: select multiMatchAllIndices(materialize('123'), materialize(['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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&&, unsigned long&) @ 0x000000000e8444da 4. DB::checkHyperscanRegexp(std::vector>, std::allocator>>> const&, unsigned long, unsigned long) @ 0x000000000e843a80 5. DB::FunctionsMultiStringSearch>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015c04c95 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aac9135 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000cccce5b 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccce65c 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd2030 10. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x00000000286fc2bd 11. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000002d9c29ae 12. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 13. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 14. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000002d34877c 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000002d34827b 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*) @ 0x000000002d36bcf7 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 21. asan_thread_start(void*) @ 0x000000000aa43059 22. ? @ 0x00007f35aab92ac3 23. ? @ 0x00007f35aac24850 2025.09.09 14:54:57.500185 [ 2686 ] {1d0eb7ea-af20-4bd9-a062-6cc58e93dcc5} TCPHandler: Code: 36. DB::Exception: Regexp length too large (2 > 1): while executing 'FUNCTION multiMatchAllIndices(materialize('123'_String) :: 3, materialize(_CAST(['12']_Array(String), 'Array(String)'_String)) :: 1) -> multiMatchAllIndices(materialize('123'_String), materialize(_CAST(['12']_Array(String), 'Array(String)'_String))) Array(UInt64) : 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&&, unsigned long&) @ 0x000000000e8444da 4. DB::checkHyperscanRegexp(std::vector>, std::allocator>>> const&, unsigned long, unsigned long) @ 0x000000000e843a80 5. DB::FunctionsMultiStringSearch>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015c04c95 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aac9135 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000cccce5b 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccce65c 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd2030 10. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x00000000286fc2bd 11. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000002d9c29ae 12. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 13. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 14. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000002d34877c 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000002d34827b 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*) @ 0x000000002d36bcf7 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 21. asan_thread_start(void*) @ 0x000000000aa43059 22. ? @ 0x00007f35aab92ac3 23. ? @ 0x00007f35aac24850 2025.09.09 14:54:57.540739 [ 2688 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 14:54:57.753527 [ 2686 ] {5acd9fa1-34ef-48c1-a385-e9f289a77ce6} executeQuery: Code: 36. DB::Exception: Total regexp lengths too large (2 > 1): while executing 'FUNCTION multiMatchAllIndices(materialize('123'_String) :: 3, materialize(_CAST(['1', '2']_Array(String), 'Array(String)'_String)) :: 1) -> multiMatchAllIndices(materialize('123'_String), materialize(_CAST(['1', '2']_Array(String), 'Array(String)'_String))) Array(UInt64) : 2'. (BAD_ARGUMENTS) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:40996) (comment: 02004_max_hyperscan_regex_length.sql) (in query: select multiMatchAllIndices(materialize('123'), materialize(['1', '2']));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, unsigned long&) @ 0x000000000cf794ba 4. DB::checkHyperscanRegexp(std::vector>, std::allocator>>> const&, unsigned long, unsigned long) @ 0x000000000e843b0a 5. DB::FunctionsMultiStringSearch>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015c04c95 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aac9135 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000cccce5b 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccce65c 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd2030 10. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x00000000286fc2bd 11. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000002d9c29ae 12. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 13. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 14. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000002d34877c 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000002d34827b 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*) @ 0x000000002d36bcf7 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 21. asan_thread_start(void*) @ 0x000000000aa43059 22. ? @ 0x00007f35aab92ac3 23. ? @ 0x00007f35aac24850 2025.09.09 14:54:57.755254 [ 2686 ] {5acd9fa1-34ef-48c1-a385-e9f289a77ce6} TCPHandler: Code: 36. DB::Exception: Total regexp lengths too large (2 > 1): while executing 'FUNCTION multiMatchAllIndices(materialize('123'_String) :: 3, materialize(_CAST(['1', '2']_Array(String), 'Array(String)'_String)) :: 1) -> multiMatchAllIndices(materialize('123'_String), materialize(_CAST(['1', '2']_Array(String), 'Array(String)'_String))) Array(UInt64) : 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, unsigned long&) @ 0x000000000cf794ba 4. DB::checkHyperscanRegexp(std::vector>, std::allocator>>> const&, unsigned long, unsigned long) @ 0x000000000e843b0a 5. DB::FunctionsMultiStringSearch>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015c04c95 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aac9135 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000cccce5b 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccce65c 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd2030 10. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x00000000286fc2bd 11. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000002d9c29ae 12. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 13. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 14. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000002d34877c 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000002d34827b 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*) @ 0x000000002d36bcf7 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 21. asan_thread_start(void*) @ 0x000000000aa43059 22. ? @ 0x00007f35aab92ac3 23. ? @ 0x00007f35aac24850 2025.09.09 14:54:57.920460 [ 2918 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:54:57.921093 [ 2920 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:54:58.092640 [ 2686 ] {7636522e-b5e5-4b2d-8fc3-52822bd5fcbf} executeQuery: Code: 36. DB::Exception: Regexp length too large (2 > 1): while executing 'FUNCTION multiFuzzyMatchAny(materialize('123'_String) :: 4, 0_UInt8 :: 2, materialize(_CAST(['12']_Array(String), 'Array(String)'_String)) :: 1) -> multiFuzzyMatchAny(materialize('123'_String), 0_UInt8, materialize(_CAST(['12']_Array(String), 'Array(String)'_String))) UInt8 : 3'. (BAD_ARGUMENTS) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:40996) (comment: 02004_max_hyperscan_regex_length.sql) (in query: select multiFuzzyMatchAny(materialize('123'), 0, materialize(['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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&&, unsigned long&) @ 0x000000000e8444da 4. DB::checkHyperscanRegexp(std::vector>, std::allocator>>> const&, unsigned long, unsigned long) @ 0x000000000e843a80 5. DB::FunctionsMultiStringFuzzySearch>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015bbc30a 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aac9135 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000cccce5b 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccce65c 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd2030 10. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x00000000286fc2bd 11. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000002d9c29ae 12. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 13. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 14. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000002d34877c 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000002d34827b 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*) @ 0x000000002d36bcf7 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 21. asan_thread_start(void*) @ 0x000000000aa43059 22. ? @ 0x00007f35aab92ac3 23. ? @ 0x00007f35aac24850 2025.09.09 14:54:58.096334 [ 2686 ] {7636522e-b5e5-4b2d-8fc3-52822bd5fcbf} TCPHandler: Code: 36. DB::Exception: Regexp length too large (2 > 1): while executing 'FUNCTION multiFuzzyMatchAny(materialize('123'_String) :: 4, 0_UInt8 :: 2, materialize(_CAST(['12']_Array(String), 'Array(String)'_String)) :: 1) -> multiFuzzyMatchAny(materialize('123'_String), 0_UInt8, materialize(_CAST(['12']_Array(String), 'Array(String)'_String))) UInt8 : 3'. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&&, unsigned long&) @ 0x000000000e8444da 4. DB::checkHyperscanRegexp(std::vector>, std::allocator>>> const&, unsigned long, unsigned long) @ 0x000000000e843a80 5. DB::FunctionsMultiStringFuzzySearch>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015bbc30a 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aac9135 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000cccce5b 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccce65c 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd2030 10. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x00000000286fc2bd 11. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000002d9c29ae 12. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 13. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 14. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000002d34877c 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000002d34827b 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*) @ 0x000000002d36bcf7 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 21. asan_thread_start(void*) @ 0x000000000aa43059 22. ? @ 0x00007f35aab92ac3 23. ? @ 0x00007f35aac24850 2025.09.09 14:54:58.276763 [ 2686 ] {d797909b-9c6b-41c1-9c3e-f178020d0d8a} executeQuery: Code: 36. DB::Exception: Total regexp lengths too large (2 > 1): while executing 'FUNCTION multiFuzzyMatchAny(materialize('123'_String) :: 4, 0_UInt8 :: 2, materialize(_CAST(['1', '2']_Array(String), 'Array(String)'_String)) :: 1) -> multiFuzzyMatchAny(materialize('123'_String), 0_UInt8, materialize(_CAST(['1', '2']_Array(String), 'Array(String)'_String))) UInt8 : 3'. (BAD_ARGUMENTS) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:40996) (comment: 02004_max_hyperscan_regex_length.sql) (in query: select multiFuzzyMatchAny(materialize('123'), 0, materialize(['1', '2']));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, unsigned long&) @ 0x000000000cf794ba 4. DB::checkHyperscanRegexp(std::vector>, std::allocator>>> const&, unsigned long, unsigned long) @ 0x000000000e843b0a 5. DB::FunctionsMultiStringFuzzySearch>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015bbc30a 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aac9135 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000cccce5b 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccce65c 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd2030 10. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x00000000286fc2bd 11. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000002d9c29ae 12. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 13. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 14. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000002d34877c 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000002d34827b 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*) @ 0x000000002d36bcf7 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 21. asan_thread_start(void*) @ 0x000000000aa43059 22. ? @ 0x00007f35aab92ac3 23. ? @ 0x00007f35aac24850 2025.09.09 14:54:58.284302 [ 2686 ] {d797909b-9c6b-41c1-9c3e-f178020d0d8a} TCPHandler: Code: 36. DB::Exception: Total regexp lengths too large (2 > 1): while executing 'FUNCTION multiFuzzyMatchAny(materialize('123'_String) :: 4, 0_UInt8 :: 2, materialize(_CAST(['1', '2']_Array(String), 'Array(String)'_String)) :: 1) -> multiFuzzyMatchAny(materialize('123'_String), 0_UInt8, materialize(_CAST(['1', '2']_Array(String), 'Array(String)'_String))) UInt8 : 3'. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, unsigned long&) @ 0x000000000cf794ba 4. DB::checkHyperscanRegexp(std::vector>, std::allocator>>> const&, unsigned long, unsigned long) @ 0x000000000e843b0a 5. DB::FunctionsMultiStringFuzzySearch>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015bbc30a 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aac9135 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000cccce5b 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccce65c 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd2030 10. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x00000000286fc2bd 11. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000002d9c29ae 12. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 13. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 14. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000002d34877c 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000002d34827b 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*) @ 0x000000002d36bcf7 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 21. asan_thread_start(void*) @ 0x000000000aa43059 22. ? @ 0x00007f35aab92ac3 23. ? @ 0x00007f35aac24850 2025.09.09 14:54:58.543631 [ 2688 ] {2e90c6c0-a04a-4959-ad58-f8d7b9b470a1} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=2, jobs=2). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:41064) (comment: 02498_analyzer_aggregate_functions_arithmetic_operations_pass_fix.sql) (in query: SELECT sum((2 * id) as func), func FROM test_table GROUP 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af80b71 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80746 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d34b5ca 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000002d3486e4 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000002d34827b 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002d36bcf7 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 12. asan_thread_start(void*) @ 0x000000000aa43059 13. ? @ 0x00007f35aab92ac3 14. ? @ 0x00007f35aac24850 2025.09.09 14:54:58.547656 [ 4021 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 14:54:58.552610 [ 2688 ] {2e90c6c0-a04a-4959-ad58-f8d7b9b470a1} 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af80b71 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80746 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d34b5ca 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000002d3486e4 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000002d34827b 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002d36bcf7 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 12. asan_thread_start(void*) @ 0x000000000aa43059 13. ? @ 0x00007f35aab92ac3 14. ? @ 0x00007f35aac24850 2025.09.09 14:54:58.799537 [ 2686 ] {2daa0c81-fbf1-4f0c-a29b-8b21ebe5bd5f} executeQuery: Code: 36. DB::Exception: Regexp length too large (2 > 1): while executing 'FUNCTION multiFuzzyMatchAnyIndex(materialize('123'_String) :: 4, 0_UInt8 :: 2, materialize(_CAST(['12']_Array(String), 'Array(String)'_String)) :: 1) -> multiFuzzyMatchAnyIndex(materialize('123'_String), 0_UInt8, materialize(_CAST(['12']_Array(String), 'Array(String)'_String))) UInt64 : 3'. (BAD_ARGUMENTS) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:40996) (comment: 02004_max_hyperscan_regex_length.sql) (in query: select multiFuzzyMatchAnyIndex(materialize('123'), 0, materialize(['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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&&, unsigned long&) @ 0x000000000e8444da 4. DB::checkHyperscanRegexp(std::vector>, std::allocator>>> const&, unsigned long, unsigned long) @ 0x000000000e843a80 5. DB::FunctionsMultiStringFuzzySearch>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015bc4002 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aac9135 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000cccce5b 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccce65c 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd2030 10. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x00000000286fc2bd 11. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000002d9c29ae 12. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 13. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 14. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000002d34877c 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000002d34827b 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*) @ 0x000000002d36bcf7 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 21. asan_thread_start(void*) @ 0x000000000aa43059 22. ? @ 0x00007f35aab92ac3 23. ? @ 0x00007f35aac24850 2025.09.09 14:54:58.810514 [ 2686 ] {2daa0c81-fbf1-4f0c-a29b-8b21ebe5bd5f} TCPHandler: Code: 36. DB::Exception: Regexp length too large (2 > 1): while executing 'FUNCTION multiFuzzyMatchAnyIndex(materialize('123'_String) :: 4, 0_UInt8 :: 2, materialize(_CAST(['12']_Array(String), 'Array(String)'_String)) :: 1) -> multiFuzzyMatchAnyIndex(materialize('123'_String), 0_UInt8, materialize(_CAST(['12']_Array(String), 'Array(String)'_String))) UInt64 : 3'. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&&, unsigned long&) @ 0x000000000e8444da 4. DB::checkHyperscanRegexp(std::vector>, std::allocator>>> const&, unsigned long, unsigned long) @ 0x000000000e843a80 5. DB::FunctionsMultiStringFuzzySearch>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015bc4002 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aac9135 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000cccce5b 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccce65c 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd2030 10. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x00000000286fc2bd 11. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000002d9c29ae 12. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 13. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 14. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000002d34877c 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000002d34827b 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*) @ 0x000000002d36bcf7 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 21. asan_thread_start(void*) @ 0x000000000aa43059 22. ? @ 0x00007f35aab92ac3 23. ? @ 0x00007f35aac24850 2025.09.09 14:54:58.923007 [ 2942 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:54:58.923405 [ 2944 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:54:59.016826 [ 2686 ] {b0fb7bd1-9da0-48a5-8708-78b357785d77} executeQuery: Code: 36. DB::Exception: Total regexp lengths too large (2 > 1): while executing 'FUNCTION multiFuzzyMatchAnyIndex(materialize('123'_String) :: 4, 0_UInt8 :: 2, materialize(_CAST(['1', '2']_Array(String), 'Array(String)'_String)) :: 1) -> multiFuzzyMatchAnyIndex(materialize('123'_String), 0_UInt8, materialize(_CAST(['1', '2']_Array(String), 'Array(String)'_String))) UInt64 : 3'. (BAD_ARGUMENTS) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:40996) (comment: 02004_max_hyperscan_regex_length.sql) (in query: select multiFuzzyMatchAnyIndex(materialize('123'), 0, materialize(['1', '2']));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, unsigned long&) @ 0x000000000cf794ba 4. DB::checkHyperscanRegexp(std::vector>, std::allocator>>> const&, unsigned long, unsigned long) @ 0x000000000e843b0a 5. DB::FunctionsMultiStringFuzzySearch>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015bc4002 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aac9135 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000cccce5b 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccce65c 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd2030 10. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x00000000286fc2bd 11. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000002d9c29ae 12. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 13. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 14. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000002d34877c 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000002d34827b 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*) @ 0x000000002d36bcf7 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 21. asan_thread_start(void*) @ 0x000000000aa43059 22. ? @ 0x00007f35aab92ac3 23. ? @ 0x00007f35aac24850 2025.09.09 14:54:59.030442 [ 2686 ] {b0fb7bd1-9da0-48a5-8708-78b357785d77} TCPHandler: Code: 36. DB::Exception: Total regexp lengths too large (2 > 1): while executing 'FUNCTION multiFuzzyMatchAnyIndex(materialize('123'_String) :: 4, 0_UInt8 :: 2, materialize(_CAST(['1', '2']_Array(String), 'Array(String)'_String)) :: 1) -> multiFuzzyMatchAnyIndex(materialize('123'_String), 0_UInt8, materialize(_CAST(['1', '2']_Array(String), 'Array(String)'_String))) UInt64 : 3'. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, unsigned long&) @ 0x000000000cf794ba 4. DB::checkHyperscanRegexp(std::vector>, std::allocator>>> const&, unsigned long, unsigned long) @ 0x000000000e843b0a 5. DB::FunctionsMultiStringFuzzySearch>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015bc4002 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aac9135 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000cccce5b 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccce65c 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd2030 10. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x00000000286fc2bd 11. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000002d9c29ae 12. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 13. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 14. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000002d34877c 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000002d34827b 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*) @ 0x000000002d36bcf7 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 21. asan_thread_start(void*) @ 0x000000000aa43059 22. ? @ 0x00007f35aab92ac3 23. ? @ 0x00007f35aac24850 2025.09.09 14:54:59.379661 [ 2686 ] {6d45ef72-e270-4d9c-ae1d-19b9085f2367} executeQuery: Code: 36. DB::Exception: Regexp length too large (2 > 1): while executing 'FUNCTION multiFuzzyMatchAllIndices(materialize('123'_String) :: 4, 0_UInt8 :: 2, materialize(_CAST(['12']_Array(String), 'Array(String)'_String)) :: 1) -> multiFuzzyMatchAllIndices(materialize('123'_String), 0_UInt8, materialize(_CAST(['12']_Array(String), 'Array(String)'_String))) Array(UInt64) : 3'. (BAD_ARGUMENTS) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:40996) (comment: 02004_max_hyperscan_regex_length.sql) (in query: select multiFuzzyMatchAllIndices(materialize('123'), 0, materialize(['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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&&, unsigned long&) @ 0x000000000e8444da 4. DB::checkHyperscanRegexp(std::vector>, std::allocator>>> const&, unsigned long, unsigned long) @ 0x000000000e843a80 5. DB::FunctionsMultiStringFuzzySearch>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015bb1410 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aac9135 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000cccce5b 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccce65c 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd2030 10. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x00000000286fc2bd 11. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000002d9c29ae 12. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 13. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 14. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000002d34877c 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000002d34827b 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*) @ 0x000000002d36bcf7 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 21. asan_thread_start(void*) @ 0x000000000aa43059 22. ? @ 0x00007f35aab92ac3 23. ? @ 0x00007f35aac24850 2025.09.09 14:54:59.382460 [ 2686 ] {6d45ef72-e270-4d9c-ae1d-19b9085f2367} TCPHandler: Code: 36. DB::Exception: Regexp length too large (2 > 1): while executing 'FUNCTION multiFuzzyMatchAllIndices(materialize('123'_String) :: 4, 0_UInt8 :: 2, materialize(_CAST(['12']_Array(String), 'Array(String)'_String)) :: 1) -> multiFuzzyMatchAllIndices(materialize('123'_String), 0_UInt8, materialize(_CAST(['12']_Array(String), 'Array(String)'_String))) Array(UInt64) : 3'. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&&, unsigned long&) @ 0x000000000e8444da 4. DB::checkHyperscanRegexp(std::vector>, std::allocator>>> const&, unsigned long, unsigned long) @ 0x000000000e843a80 5. DB::FunctionsMultiStringFuzzySearch>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015bb1410 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aac9135 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000cccce5b 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccce65c 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd2030 10. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x00000000286fc2bd 11. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000002d9c29ae 12. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 13. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 14. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000002d34877c 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000002d34827b 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*) @ 0x000000002d36bcf7 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 21. asan_thread_start(void*) @ 0x000000000aa43059 22. ? @ 0x00007f35aab92ac3 23. ? @ 0x00007f35aac24850 2025.09.09 14:54:59.526039 [ 4021 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 14:54:59.604177 [ 2686 ] {427fc1b1-1010-4ac5-8d85-e5e0d2ee5b80} executeQuery: Code: 36. DB::Exception: Total regexp lengths too large (2 > 1): while executing 'FUNCTION multiFuzzyMatchAllIndices(materialize('123'_String) :: 4, 0_UInt8 :: 2, materialize(_CAST(['1', '2']_Array(String), 'Array(String)'_String)) :: 1) -> multiFuzzyMatchAllIndices(materialize('123'_String), 0_UInt8, materialize(_CAST(['1', '2']_Array(String), 'Array(String)'_String))) Array(UInt64) : 3'. (BAD_ARGUMENTS) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:40996) (comment: 02004_max_hyperscan_regex_length.sql) (in query: select multiFuzzyMatchAllIndices(materialize('123'), 0, materialize(['1', '2']));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, unsigned long&) @ 0x000000000cf794ba 4. DB::checkHyperscanRegexp(std::vector>, std::allocator>>> const&, unsigned long, unsigned long) @ 0x000000000e843b0a 5. DB::FunctionsMultiStringFuzzySearch>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015bb1410 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aac9135 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000cccce5b 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccce65c 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd2030 10. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x00000000286fc2bd 11. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000002d9c29ae 12. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 13. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 14. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000002d34877c 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000002d34827b 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*) @ 0x000000002d36bcf7 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 21. asan_thread_start(void*) @ 0x000000000aa43059 22. ? @ 0x00007f35aab92ac3 23. ? @ 0x00007f35aac24850 2025.09.09 14:54:59.607168 [ 2686 ] {427fc1b1-1010-4ac5-8d85-e5e0d2ee5b80} TCPHandler: Code: 36. DB::Exception: Total regexp lengths too large (2 > 1): while executing 'FUNCTION multiFuzzyMatchAllIndices(materialize('123'_String) :: 4, 0_UInt8 :: 2, materialize(_CAST(['1', '2']_Array(String), 'Array(String)'_String)) :: 1) -> multiFuzzyMatchAllIndices(materialize('123'_String), 0_UInt8, materialize(_CAST(['1', '2']_Array(String), 'Array(String)'_String))) Array(UInt64) : 3'. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, unsigned long&) @ 0x000000000cf794ba 4. DB::checkHyperscanRegexp(std::vector>, std::allocator>>> const&, unsigned long, unsigned long) @ 0x000000000e843b0a 5. DB::FunctionsMultiStringFuzzySearch>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015bb1410 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aac9135 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000cccce5b 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccce65c 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd2030 10. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x00000000286fc2bd 11. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000002d9c29ae 12. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 13. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 14. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000002d34877c 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000002d34827b 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*) @ 0x000000002d36bcf7 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 21. asan_thread_start(void*) @ 0x000000000aa43059 22. ? @ 0x00007f35aab92ac3 23. ? @ 0x00007f35aac24850 2025.09.09 14:54:59.925158 [ 2958 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:54:59.925775 [ 2960 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:55:00.527611 [ 3640 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 14:55:00.927192 [ 2980 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:55:00.927949 [ 2973 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:55:01.173129 [ 2688 ] {3e8e8c07-46a9-4126-92d8-f8073eefd1a8} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=773, jobs=732). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:57660) (comment: 01246_least_greatest_generic.sql) (in query: SELECT LEAST(-1, 18446744073709551615) x, toTypeName(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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af872f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af7b2d1 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af7c3f3 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d36920d 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000002d369e5f 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processOrdinaryQuery() @ 0x000000002d18af7b 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d17644a 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 15. asan_thread_start(void*) @ 0x000000000aa43059 16. ? @ 0x00007f35aab92ac3 17. ? @ 0x00007f35aac24850 2025.09.09 14:55:01.174920 [ 2688 ] {3e8e8c07-46a9-4126-92d8-f8073eefd1a8} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=773, jobs=732). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af872f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af7b2d1 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af7c3f3 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d36920d 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000002d369e5f 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processOrdinaryQuery() @ 0x000000002d18af7b 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d17644a 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 15. asan_thread_start(void*) @ 0x000000000aa43059 16. ? @ 0x00007f35aab92ac3 17. ? @ 0x00007f35aac24850 2025.09.09 14:55:01.526950 [ 2688 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 14:55:01.929161 [ 2995 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:55:01.929781 [ 2992 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:55:02.558920 [ 4023 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 14:55:02.931077 [ 3022 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:55:02.941834 [ 4023 ] {946719b1-9642-4a7d-99e5-70196b549404} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=773, jobs=736). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:59368) (comment: 03456_match_index_prefix_extraction.sql) (in query: SELECT count() AS `count()` FROM `test_3`.`foo` AS `__table1` WHERE match(`__table1`.`path`, '^xxx\\^zzz')), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af872f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af7b2d1 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af7c3f3 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d36920d 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000002d369e5f 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processOrdinaryQuery() @ 0x000000002d18af7b 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d17644a 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 15. asan_thread_start(void*) @ 0x000000000aa43059 16. ? @ 0x00007f35aab92ac3 17. ? @ 0x00007f35aac24850 2025.09.09 14:55:02.943484 [ 4023 ] {946719b1-9642-4a7d-99e5-70196b549404} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=773, jobs=736). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af872f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af7b2d1 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af7c3f3 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d36920d 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000002d369e5f 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processOrdinaryQuery() @ 0x000000002d18af7b 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d17644a 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 15. asan_thread_start(void*) @ 0x000000000aa43059 16. ? @ 0x00007f35aab92ac3 17. ? @ 0x00007f35aac24850 2025.09.09 14:55:02.981965 [ 4021 ] {35e928ad-5a04-4ecc-8fef-201fbb3badaf} executeQuery: Code: 439. DB::Exception: Received from 127.0.0.5:9000. DB::Exception: Cannot schedule a task: fault injected (threads=773, jobs=736). Stack trace: 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af872f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af7b2d1 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af7c3f3 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d36920d 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000002d369e5f 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processOrdinaryQuery() @ 0x000000002d18af7b 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d17644a 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 15. asan_thread_start(void*) @ 0x000000000aa43059 16. ? @ 0x00007f35aab92ac3 17. ? @ 0x00007f35aac24850 : While executing Remote. (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:57684) (comment: 03456_match_index_prefix_extraction.sql) (in query: SELECT count() FROM foo WHERE match(path, '^xxx\\^zzz') SETTINGS force_primary_key = 1;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. ./contrib/llvm-project/libcxx/include/string:1499: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x000000001aeb974e 3. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::Connection::receiveException() const @ 0x000000002cee6c6a 4. ./build_docker/./src/Client/Connection.cpp:0: DB::Connection::receivePacket() @ 0x000000002cef780e 5. ./build_docker/./src/Client/MultiplexedConnections.cpp:340: DB::MultiplexedConnections::receivePacketUnlocked(std::function) @ 0x000000002cf8e09e 6. ./build_docker/./src/QueryPipeline/RemoteQueryExecutorReadContext.cpp:0: DB::RemoteQueryExecutorReadContext::Task::run(std::function, std::function) @ 0x00000000278ad616 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000278ab436 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000278aaa44 9. ./contrib/boost/boost/context/fiber_ucontext.hpp:82: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x00000000278a8394 2025.09.09 14:55:02.984978 [ 4021 ] {35e928ad-5a04-4ecc-8fef-201fbb3badaf} TCPHandler: Code: 439. DB::Exception: Received from 127.0.0.5:9000. DB::Exception: Cannot schedule a task: fault injected (threads=773, jobs=736). Stack trace: 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af872f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af7b2d1 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af7c3f3 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d36920d 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000002d369e5f 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processOrdinaryQuery() @ 0x000000002d18af7b 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d17644a 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 15. asan_thread_start(void*) @ 0x000000000aa43059 16. ? @ 0x00007f35aab92ac3 17. ? @ 0x00007f35aac24850 : 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. ./contrib/llvm-project/libcxx/include/string:1499: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x000000001aeb974e 3. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::Connection::receiveException() const @ 0x000000002cee6c6a 4. ./build_docker/./src/Client/Connection.cpp:0: DB::Connection::receivePacket() @ 0x000000002cef780e 5. ./build_docker/./src/Client/MultiplexedConnections.cpp:340: DB::MultiplexedConnections::receivePacketUnlocked(std::function) @ 0x000000002cf8e09e 6. ./build_docker/./src/QueryPipeline/RemoteQueryExecutorReadContext.cpp:0: DB::RemoteQueryExecutorReadContext::Task::run(std::function, std::function) @ 0x00000000278ad616 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000278ab436 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000278aaa44 9. ./contrib/boost/boost/context/fiber_ucontext.hpp:82: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x00000000278a8394 2025.09.09 14:55:02.996128 [ 3017 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:55:03.591913 [ 4023 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 14:55:03.948513 [ 3040 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:55:04.007734 [ 3041 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:55:04.614432 [ 4017 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 14:55:04.950441 [ 3066 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:55:05.009807 [ 3070 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:55:05.615593 [ 4023 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 14:55:05.952756 [ 3100 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:55:06.011836 [ 3103 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:55:06.357911 [ 3612 ] {} DynamicQueryHandler: Code: 452. DB::Exception: Setting max_execution_time shouldn't be greater than 60. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x0000000026f841fa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:368: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f81de0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/find_if.h:25: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f808a4 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000002d065739 10. ./build_docker/./src/Server/HTTPHandler.cpp:705: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000002d06d139 11. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000002d1cc337 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 15. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 16. asan_thread_start(void*) @ 0x000000000aa43059 17. ? @ 0x00007f35aab92ac3 18. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:55:06.611437 [ 4023 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 14:55:06.955220 [ 3144 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:55:07.016618 [ 3143 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:55:07.648947 [ 4023 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 14:55:07.958098 [ 3165 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:55:08.018973 [ 3166 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:55:08.695284 [ 4023 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 14:55:08.960735 [ 3206 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:55:09.021421 [ 3204 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:55:09.824529 [ 4023 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 14:55:09.963086 [ 3241 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:55:10.023560 [ 2732 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:55:10.849485 [ 4023 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 14:55:10.966620 [ 2767 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:55:11.030844 [ 2773 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:55:11.916612 [ 4023 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 14:55:11.969146 [ 2811 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:55:12.034489 [ 2809 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:55:12.930474 [ 4023 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 14:55:12.971262 [ 2842 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:55:13.036822 [ 2837 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:55:13.959713 [ 4017 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 14:55:13.973275 [ 2876 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:55:14.040909 [ 2871 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:55:14.974622 [ 4017 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 14:55:14.975577 [ 2911 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:55:15.042784 [ 2912 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:55:15.447095 [ 4017 ] {8a140b0e-3acc-4b21-b1ad-e06d6248dec0} 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.10505.altinitytest (altinity build)) (from [::1]:48432) (comment: 02725_agg_projection_resprect_PK.sql) (in query: INSERT INTO t0 SELECT number, -number, number FROM numbers_mt(1e5);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af819ed 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80746 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d34b5ca 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000002d3486e4 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000002d34827b 9. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:57: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002d3463e7 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 12. asan_thread_start(void*) @ 0x000000000aa43059 13. ? @ 0x00007f35aab92ac3 14. ? @ 0x00007f35aac24850 2025.09.09 14:55:15.466266 [ 4017 ] {8a140b0e-3acc-4b21-b1ad-e06d6248dec0} 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af819ed 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80746 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d34b5ca 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000002d3486e4 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000002d34827b 9. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:57: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002d3463e7 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 12. asan_thread_start(void*) @ 0x000000000aa43059 13. ? @ 0x00007f35aab92ac3 14. ? @ 0x00007f35aac24850 2025.09.09 14:55:15.978299 [ 2931 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:55:15.986678 [ 4017 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 14:55:16.045204 [ 2933 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:55:16.699960 [ 4017 ] {31b05107-cd79-4423-a04d-fc518fbd363f} executeQuery: Code: 475. DB::Exception: Multiple WITH FILL for identical expressions is not supported in ORDER BY. (INVALID_WITH_FILL_EXPRESSION) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:48456) (comment: 02018_multiple_with_fill_for_the_same_column.sql) (in query: SELECT x, y FROM (SELECT 5 AS x, 'Hello' AS y) ORDER BY x WITH FILL FROM 3 TO 7, y, x WITH FILL FROM 1 TO 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aac868e 4. ./build_docker/./src/Processors/Transforms/FillingTransform.cpp:250: DB::FillingTransform::FillingTransform(DB::Block const&, DB::SortDescription const&, DB::SortDescription const&, std::shared_ptr, bool) @ 0x000000002dd98c62 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000002dd91fac 6. ./build_docker/./src/QueryPipeline/Pipe.cpp:591: DB::Pipe::addSimpleTransform(std::function (DB::Block const&, DB::Pipe::StreamType)> const&)::$_0::operator()(DB::OutputPort*&, DB::Pipe::StreamType) const @ 0x000000002780b1b7 7. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::Pipe::addSimpleTransform(std::function (DB::Block const&, DB::Pipe::StreamType)> const&) @ 0x000000002780abfd 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002dd90c15 9. ./build_docker/./src/Processors/QueryPlan/ITransformingStep.cpp:0: DB::ITransformingStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000002ddba428 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000002ddff11e 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000002942117f 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x00000000294209e7 13. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b382fc 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 16. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 20. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 21. asan_thread_start(void*) @ 0x000000000aa43059 22. ? @ 0x00007f35aab92ac3 23. ? @ 0x00007f35aac24850 2025.09.09 14:55:16.707369 [ 4017 ] {31b05107-cd79-4423-a04d-fc518fbd363f} TCPHandler: Code: 475. DB::Exception: Multiple WITH FILL for identical expressions is not supported in ORDER BY. (INVALID_WITH_FILL_EXPRESSION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aac868e 4. ./build_docker/./src/Processors/Transforms/FillingTransform.cpp:250: DB::FillingTransform::FillingTransform(DB::Block const&, DB::SortDescription const&, DB::SortDescription const&, std::shared_ptr, bool) @ 0x000000002dd98c62 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000002dd91fac 6. ./build_docker/./src/QueryPipeline/Pipe.cpp:591: DB::Pipe::addSimpleTransform(std::function (DB::Block const&, DB::Pipe::StreamType)> const&)::$_0::operator()(DB::OutputPort*&, DB::Pipe::StreamType) const @ 0x000000002780b1b7 7. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::Pipe::addSimpleTransform(std::function (DB::Block const&, DB::Pipe::StreamType)> const&) @ 0x000000002780abfd 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002dd90c15 9. ./build_docker/./src/Processors/QueryPlan/ITransformingStep.cpp:0: DB::ITransformingStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000002ddba428 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000002ddff11e 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000002942117f 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x00000000294209e7 13. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b382fc 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 16. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 20. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 21. asan_thread_start(void*) @ 0x000000000aa43059 22. ? @ 0x00007f35aab92ac3 23. ? @ 0x00007f35aac24850 2025.09.09 14:55:16.980632 [ 2954 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:55:17.047404 [ 2957 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:55:17.173456 [ 4017 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 14:55:17.982806 [ 2980 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:55:18.049450 [ 2981 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:55:18.209002 [ 4022 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 14:55:18.985064 [ 3008 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:55:19.051655 [ 3004 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:55:19.251574 [ 4022 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 14:55:19.987408 [ 3010 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:55:20.053558 [ 3014 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:55:20.340393 [ 4022 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 14:55:20.686212 [ 3722 ] {c08fcd50-847e-4ce1-b0e7-038b9f7b63e8} executeQuery: Code: 36. DB::Exception: Path of the custom local disk must be inside `/var/lib/clickhouse/disks/` directory: While processing disk(type = local, path = '/local/'). (BAD_ARGUMENTS) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:39790) (comment: 02454_create_table_with_custom_disk.sql) (in query: CREATE TABLE test (a Int32) ENGINE = MergeTree() order by tuple() SETTINGS disk = disk(type=local, path='/local/');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x000000000aafc574 4. ./build_docker/./src/Disks/DiskFomAST.cpp:88: DB::getOrCreateCustomDisk(Poco::AutoPtr, String const&, std::shared_ptr, bool) @ 0x000000002c8b7709 5. ./base/poco/Foundation/include/Poco/AutoPtr.h:90: DB::DiskConfigurationFlattener::visit(std::shared_ptr&, DB::DiskConfigurationFlattener::Data&) @ 0x000000002c8b9d22 6. ./src/Interpreters/InDepthNodeVisitor.h:78: DB::InDepthNodeVisitor>::doVisit(std::shared_ptr&) @ 0x000000002c8b979f 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:807: DB::DiskFomAST::createCustomDisk(std::shared_ptr const&, std::shared_ptr, bool) @ 0x000000002c8b7e46 8. ./src/Common/Logger.h:41: DB::MergeTreeSettings::loadFromQuery(DB::ASTStorage&, std::shared_ptr, bool) @ 0x000000002c84c42d 9. ./build_docker/./src/Storages/MergeTree/registerStorageMergeTree.cpp:0: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000002cb9f518 10. ./build_docker/./src/Storages/StorageFactory.cpp:225: DB::StorageFactory::get(DB::ASTCreateQuery const&, String const&, std::shared_ptr, std::shared_ptr, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, DB::LoadingStrictnessLevel) const @ 0x000000002b77bf53 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291b9254 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291ac835 13. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000291c3415 14. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b382fc 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 17. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 21. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 22. asan_thread_start(void*) @ 0x000000000aa43059 23. ? @ 0x00007f35aab92ac3 24. ? @ 0x00007f35aac24850 2025.09.09 14:55:20.689092 [ 3722 ] {c08fcd50-847e-4ce1-b0e7-038b9f7b63e8} TCPHandler: Code: 36. DB::Exception: Path of the custom local disk must be inside `/var/lib/clickhouse/disks/` directory: While processing disk(type = local, path = '/local/'). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x000000000aafc574 4. ./build_docker/./src/Disks/DiskFomAST.cpp:88: DB::getOrCreateCustomDisk(Poco::AutoPtr, String const&, std::shared_ptr, bool) @ 0x000000002c8b7709 5. ./base/poco/Foundation/include/Poco/AutoPtr.h:90: DB::DiskConfigurationFlattener::visit(std::shared_ptr&, DB::DiskConfigurationFlattener::Data&) @ 0x000000002c8b9d22 6. ./src/Interpreters/InDepthNodeVisitor.h:78: DB::InDepthNodeVisitor>::doVisit(std::shared_ptr&) @ 0x000000002c8b979f 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:807: DB::DiskFomAST::createCustomDisk(std::shared_ptr const&, std::shared_ptr, bool) @ 0x000000002c8b7e46 8. ./src/Common/Logger.h:41: DB::MergeTreeSettings::loadFromQuery(DB::ASTStorage&, std::shared_ptr, bool) @ 0x000000002c84c42d 9. ./build_docker/./src/Storages/MergeTree/registerStorageMergeTree.cpp:0: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000002cb9f518 10. ./build_docker/./src/Storages/StorageFactory.cpp:225: DB::StorageFactory::get(DB::ASTCreateQuery const&, String const&, std::shared_ptr, std::shared_ptr, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, DB::LoadingStrictnessLevel) const @ 0x000000002b77bf53 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291b9254 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291ac835 13. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000291c3415 14. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b382fc 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 17. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 21. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 22. asan_thread_start(void*) @ 0x000000000aa43059 23. ? @ 0x00007f35aab92ac3 24. ? @ 0x00007f35aac24850 2025.09.09 14:55:20.989782 [ 3039 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:55:21.055595 [ 3040 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:55:21.391423 [ 4022 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 14:55:21.992044 [ 3066 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:55:22.061346 [ 3073 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:55:22.489041 [ 4022 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 14:55:22.995020 [ 3088 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:55:23.064242 [ 3084 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:55:23.665650 [ 4022 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 14:55:23.773963 [ 3722 ] {54cef8d4-8649-4925-81ca-d6b18208a005} executeQuery: Code: 69. DB::Exception: The argument 'resolution' (24) of function geoToH3 is out of bounds because the maximum resolution in H3 library is 15: In scope SELECT geoToH3(37.63098076, 55.77922738, 24). (ARGUMENT_OUT_OF_BOUND) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:39800) (comment: 00926_geo_to_h3.sql) (in query: select geoToH3(37.63098076, 55.77922738, 24);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, int&&) @ 0x000000000fffa700 4. DB::(anonymous namespace)::FunctionGeoToH3::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000fff8aba 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aa8c635 6. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aac91d5 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000cccccfb 8. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000cccc1ab 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccccc2a 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccce65c 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd2030 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002839a3af 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000028367bce 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028366290 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283b62c9 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002835ae03 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000028359104 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000028357f0d 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002921bdcc 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&) @ 0x000000002941f313 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&) @ 0x0000000029419aef 22. ./contrib/llvm-project/libcxx/include/vector:432: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000029421f5d 23. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000029344c1b 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*) @ 0x0000000029b3703b 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 27. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 31. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 2025.09.09 14:55:23.779488 [ 3722 ] {54cef8d4-8649-4925-81ca-d6b18208a005} TCPHandler: Code: 69. DB::Exception: The argument 'resolution' (24) of function geoToH3 is out of bounds because the maximum resolution in H3 library is 15: In scope SELECT geoToH3(37.63098076, 55.77922738, 24). (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, int&&) @ 0x000000000fffa700 4. DB::(anonymous namespace)::FunctionGeoToH3::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000fff8aba 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aa8c635 6. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aac91d5 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000cccccfb 8. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000cccc1ab 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccccc2a 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccce65c 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd2030 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002839a3af 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000028367bce 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028366290 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283b62c9 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002835ae03 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000028359104 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000028357f0d 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002921bdcc 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&) @ 0x000000002941f313 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&) @ 0x0000000029419aef 22. ./contrib/llvm-project/libcxx/include/vector:432: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000029421f5d 23. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000029344c1b 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*) @ 0x0000000029b3703b 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 27. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 31. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 2025.09.09 14:55:23.998043 [ 3105 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:55:24.066724 [ 3103 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:55:24.670448 [ 3722 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 14:55:25.073440 [ 3125 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:55:25.073605 [ 3123 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:55:25.686251 [ 4022 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 14:55:26.111091 [ 3140 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:55:26.111706 [ 3146 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:55:26.415257 [ 3612 ] {} DynamicQueryHandler: Code: 452. DB::Exception: Setting max_execution_time shouldn't be greater than 60. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x0000000026f841fa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:368: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f81de0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/find_if.h:25: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f808a4 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000002d065739 10. ./build_docker/./src/Server/HTTPHandler.cpp:705: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000002d06d139 11. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000002d1cc337 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 15. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 16. asan_thread_start(void*) @ 0x000000000aa43059 17. ? @ 0x00007f35aab92ac3 18. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:55:26.460404 [ 3160 ] {} 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af819ed 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80746 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000263a174e 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000286c6b9c 8. ./contrib/llvm-project/libcxx/include/vector:590: DB::DatabaseCatalog::dropTableDataTask() @ 0x00000000286c7466 9. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 11. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 14. asan_thread_start(void*) @ 0x000000000aa43059 15. ? @ 0x00007f35aab92ac3 16. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:55:26.693689 [ 3722 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 14:55:27.113494 [ 3167 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:55:27.114220 [ 3170 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:55:27.693877 [ 3722 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 14:55:28.117290 [ 3184 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:55:28.118432 [ 3186 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:55:28.225509 [ 3722 ] {b7f89e08-3a03-486f-8642-70eae1088e4b} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=773, jobs=732). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:39886) (comment: 03200_memory_engine_alter_dynamic.sql) (in query: insert into table test select * 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af872f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af7b2d1 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af7c3f3 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d345317 7. ./build_docker/./src/Server/TCPHandler.cpp:621: DB::TCPHandler::runImpl() @ 0x000000002d176603 8. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 12. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 13. asan_thread_start(void*) @ 0x000000000aa43059 14. ? @ 0x00007f35aab92ac3 15. ? @ 0x00007f35aac24850 2025.09.09 14:55:28.239895 [ 3722 ] {b7f89e08-3a03-486f-8642-70eae1088e4b} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=773, jobs=732). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af872f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af7b2d1 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af7c3f3 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d345317 7. ./build_docker/./src/Server/TCPHandler.cpp:621: DB::TCPHandler::runImpl() @ 0x000000002d176603 8. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 12. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 13. asan_thread_start(void*) @ 0x000000000aa43059 14. ? @ 0x00007f35aab92ac3 15. ? @ 0x00007f35aac24850 2025.09.09 14:55:28.746234 [ 3722 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 14:55:29.119789 [ 3201 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:55:29.120442 [ 3203 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:55:29.754968 [ 4022 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 14:55:30.121646 [ 3229 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:55:30.131956 [ 3228 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:55:30.714154 [ 3722 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 14:55:31.123992 [ 3232 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:55:31.134018 [ 3238 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:55:31.709086 [ 4022 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 14:55:32.126152 [ 2746 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:55:32.136584 [ 2737 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:55:32.739795 [ 4022 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 14:55:33.128416 [ 2763 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:55:33.138767 [ 2755 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:55:33.728741 [ 3722 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 14:55:34.130669 [ 2782 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:55:34.140801 [ 2781 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:55:34.812545 [ 5359 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 14:55:35.094402 [ 4017 ] {12ced67d-7ceb-4e31-b24c-ae104d502219} executeQuery: Code: 48. DB::Exception: Conditional functions with different Decimal scales. (NOT_IMPLEMENTED) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:48476) (comment: 00700_decimal_complex_types.sql) (in query: SELECT number % 2 ? toDecimal32('32.1', 5) : toDecimal32('32.2', 1) FROM system.numbers LIMIT 2;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aac868e 4. unsigned int DB::(anonymous namespace)::FunctionIf::decimalScale, DB::Decimal>(std::vector> const&) @ 0x0000000011f02675 5. bool DB::callOnBasicType, true, true, true, false, DB::(anonymous namespace)::FunctionIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&)&>(DB::TypeIndex, DB::(anonymous namespace)::FunctionIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&)&) @ 0x0000000011dc47e1 6. DB::(anonymous namespace)::FunctionIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000011c341bf 7. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aa8c635 8. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aac91d5 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000cccccfb 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccce65c 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd2030 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x0000000028259428 13. ./contrib/llvm-project/libcxx/include/vector:961: DB::ActionsDAG::updateHeader(DB::Block const&) const @ 0x0000000028256e17 14. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:10: DB::ExpressionTransform::transformHeader(DB::Block const&, DB::ActionsDAG const&) @ 0x000000002d9c2197 15. ./build_docker/./src/Processors/QueryPlan/ExpressionStep.cpp:0: DB::ExpressionStep::ExpressionStep(DB::DataStream const&, DB::ActionsDAG) @ 0x000000002dd8d279 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::(anonymous namespace)::addExpressionStep(DB::QueryPlan&, std::shared_ptr&, String const&, std::unordered_set, std::hash>, std::equal_to>, std::allocator>>&) @ 0x000000002943bd73 17. ./contrib/llvm-project/libcxx/include/string:1499: DB::Planner::buildPlanForQueryNode() @ 0x0000000029434460 18. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x00000000294261fb 19. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000029421552 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1182: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3737e 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 27. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 28. asan_thread_start(void*) @ 0x000000000aa43059 29. ? @ 0x00007f35aab92ac3 30. ? @ 0x00007f35aac24850 2025.09.09 14:55:35.098801 [ 4017 ] {12ced67d-7ceb-4e31-b24c-ae104d502219} TCPHandler: Code: 48. DB::Exception: Conditional functions with different Decimal scales. (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aac868e 4. unsigned int DB::(anonymous namespace)::FunctionIf::decimalScale, DB::Decimal>(std::vector> const&) @ 0x0000000011f02675 5. bool DB::callOnBasicType, true, true, true, false, DB::(anonymous namespace)::FunctionIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&)&>(DB::TypeIndex, DB::(anonymous namespace)::FunctionIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&)&) @ 0x0000000011dc47e1 6. DB::(anonymous namespace)::FunctionIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000011c341bf 7. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aa8c635 8. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aac91d5 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000cccccfb 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccce65c 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd2030 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x0000000028259428 13. ./contrib/llvm-project/libcxx/include/vector:961: DB::ActionsDAG::updateHeader(DB::Block const&) const @ 0x0000000028256e17 14. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:10: DB::ExpressionTransform::transformHeader(DB::Block const&, DB::ActionsDAG const&) @ 0x000000002d9c2197 15. ./build_docker/./src/Processors/QueryPlan/ExpressionStep.cpp:0: DB::ExpressionStep::ExpressionStep(DB::DataStream const&, DB::ActionsDAG) @ 0x000000002dd8d279 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::(anonymous namespace)::addExpressionStep(DB::QueryPlan&, std::shared_ptr&, String const&, std::unordered_set, std::hash>, std::equal_to>, std::allocator>>&) @ 0x000000002943bd73 17. ./contrib/llvm-project/libcxx/include/string:1499: DB::Planner::buildPlanForQueryNode() @ 0x0000000029434460 18. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x00000000294261fb 19. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000029421552 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1182: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3737e 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 27. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 28. asan_thread_start(void*) @ 0x000000000aa43059 29. ? @ 0x00007f35aab92ac3 30. ? @ 0x00007f35aac24850 2025.09.09 14:55:35.132767 [ 2806 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:55:35.142847 [ 2803 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:55:35.212005 [ 4017 ] {3bd2b379-7778-4c2a-bac9-43bf8a85bff0} executeQuery: Code: 48. DB::Exception: Conditional functions with different Decimal scales. (NOT_IMPLEMENTED) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:48476) (comment: 00700_decimal_complex_types.sql) (in query: SELECT number % 2 ? toDecimal32('32.1', 5) : toDecimal64('64.2', 2) FROM system.numbers LIMIT 2;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aac868e 4. unsigned int DB::(anonymous namespace)::FunctionIf::decimalScale, DB::Decimal>(std::vector> const&) @ 0x0000000011f03895 5. bool DB::callOnBasicType, true, true, true, false, DB::(anonymous namespace)::FunctionIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&)&>(DB::TypeIndex, DB::(anonymous namespace)::FunctionIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&)&) @ 0x0000000011dc4671 6. DB::(anonymous namespace)::FunctionIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000011c341bf 7. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aa8c635 8. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aac91d5 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000cccccfb 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccce65c 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd2030 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x0000000028259428 13. ./contrib/llvm-project/libcxx/include/vector:961: DB::ActionsDAG::updateHeader(DB::Block const&) const @ 0x0000000028256e17 14. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:10: DB::ExpressionTransform::transformHeader(DB::Block const&, DB::ActionsDAG const&) @ 0x000000002d9c2197 15. ./build_docker/./src/Processors/QueryPlan/ExpressionStep.cpp:0: DB::ExpressionStep::ExpressionStep(DB::DataStream const&, DB::ActionsDAG) @ 0x000000002dd8d279 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::(anonymous namespace)::addExpressionStep(DB::QueryPlan&, std::shared_ptr&, String const&, std::unordered_set, std::hash>, std::equal_to>, std::allocator>>&) @ 0x000000002943bd73 17. ./contrib/llvm-project/libcxx/include/string:1499: DB::Planner::buildPlanForQueryNode() @ 0x0000000029434460 18. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x00000000294261fb 19. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000029421552 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1182: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3737e 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 27. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 28. asan_thread_start(void*) @ 0x000000000aa43059 29. ? @ 0x00007f35aab92ac3 30. ? @ 0x00007f35aac24850 2025.09.09 14:55:35.214735 [ 4017 ] {3bd2b379-7778-4c2a-bac9-43bf8a85bff0} TCPHandler: Code: 48. DB::Exception: Conditional functions with different Decimal scales. (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aac868e 4. unsigned int DB::(anonymous namespace)::FunctionIf::decimalScale, DB::Decimal>(std::vector> const&) @ 0x0000000011f03895 5. bool DB::callOnBasicType, true, true, true, false, DB::(anonymous namespace)::FunctionIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&)&>(DB::TypeIndex, DB::(anonymous namespace)::FunctionIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&)&) @ 0x0000000011dc4671 6. DB::(anonymous namespace)::FunctionIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000011c341bf 7. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aa8c635 8. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aac91d5 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000cccccfb 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccce65c 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd2030 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x0000000028259428 13. ./contrib/llvm-project/libcxx/include/vector:961: DB::ActionsDAG::updateHeader(DB::Block const&) const @ 0x0000000028256e17 14. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:10: DB::ExpressionTransform::transformHeader(DB::Block const&, DB::ActionsDAG const&) @ 0x000000002d9c2197 15. ./build_docker/./src/Processors/QueryPlan/ExpressionStep.cpp:0: DB::ExpressionStep::ExpressionStep(DB::DataStream const&, DB::ActionsDAG) @ 0x000000002dd8d279 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::(anonymous namespace)::addExpressionStep(DB::QueryPlan&, std::shared_ptr&, String const&, std::unordered_set, std::hash>, std::equal_to>, std::allocator>>&) @ 0x000000002943bd73 17. ./contrib/llvm-project/libcxx/include/string:1499: DB::Planner::buildPlanForQueryNode() @ 0x0000000029434460 18. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x00000000294261fb 19. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000029421552 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1182: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3737e 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 27. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 28. asan_thread_start(void*) @ 0x000000000aa43059 29. ? @ 0x00007f35aab92ac3 30. ? @ 0x00007f35aac24850 2025.09.09 14:55:35.339733 [ 3326 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {166e6d4b-ecec-41a4-ad4a-0c1c77ff9a47::202509_103_108_1}: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=13, jobs=0). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af80b71 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80746 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002c765aab 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:1197: ? @ 0x000000002c7602b8 8. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x000000002c75fc2b 9. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:0: DB::MergeTreeReaderCompact::MergeTreeReaderCompact(std::shared_ptr, DB::NamesAndTypesList, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*, DB::MarkCache*, DB::MarkRanges, DB::MergeTreeReaderSettings, std::map, std::allocator>>, std::function const&, int) @ 0x000000002c7aee03 10. ./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.h:16: DB::MergeTreeReaderCompactSingleBuffer::MergeTreeReaderCompactSingleBuffer&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int&&) @ 0x000000002c5d6d21 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::MergeTreeDataPartCompact::getReader(DB::NamesAndTypesList const&, std::shared_ptr const&, DB::MarkRanges const&, std::unordered_map, std::equal_to, std::allocator>> const&, DB::UncompressedCache*, DB::MarkCache*, std::shared_ptr const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) const @ 0x000000002c5d1037 12. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:169: DB::MergeTreeSequentialSource::MergeTreeSequentialSource(DB::MergeTreeSequentialSourceType, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::vector>, std::optional, bool, bool, bool) @ 0x000000002c80c330 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:35: DB::MergeTreeSequentialSource* std::construct_at[abi:v15007] const&, std::shared_ptr&, std::shared_ptr&, std::vector>&, std::optional, bool, bool&, bool&, DB::MergeTreeSequentialSource*>(DB::MergeTreeSequentialSource*, DB::MergeTreeSequentialSourceType&, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr&, std::shared_ptr&, std::vector>&, std::optional&&, bool&&, bool&, bool&) @ 0x000000002c81320f 14. ./contrib/llvm-project/libcxx/include/__memory/allocator_traits.h:298: DB::createMergeTreeSequentialSource(DB::MergeTreeSequentialSourceType, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::vector>, std::optional, std::shared_ptr>, bool, bool, bool) @ 0x000000002c810812 15. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1136: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::createMergedStream() @ 0x000000002c3dd079 16. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() @ 0x000000002c3d6516 17. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:534: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x000000002c3e2799 18. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::execute() @ 0x000000002c3ef3fe 19. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:0: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000002cc2f4c0 20. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000002c427f28 21. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000002c429675 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7eaf0 23. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001af8a79f 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 26. asan_thread_start(void*) @ 0x000000000aa43059 27. ? @ 0x00007f35aab92ac3 28. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:55:35.458888 [ 4017 ] {0dc75393-691b-434f-95a5-bc3bd47aee49} executeQuery: Code: 48. DB::Exception: Conditional functions with different Decimal scales. (NOT_IMPLEMENTED) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:48476) (comment: 00700_decimal_complex_types.sql) (in query: SELECT number % 2 ? toDecimal32('32.1', 5) : toDecimal128('128.2', 3) FROM system.numbers LIMIT 2;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aac868e 4. unsigned int DB::(anonymous namespace)::FunctionIf::decimalScale, DB::Decimal>>(std::vector> const&) @ 0x0000000011f04ab5 5. bool DB::callOnBasicType, true, true, true, false, DB::(anonymous namespace)::FunctionIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&)&>(DB::TypeIndex, DB::(anonymous namespace)::FunctionIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&)&) @ 0x0000000011dc3e90 6. DB::(anonymous namespace)::FunctionIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000011c341bf 7. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aa8c635 8. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aac91d5 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000cccccfb 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccce65c 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd2030 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x0000000028259428 13. ./contrib/llvm-project/libcxx/include/vector:961: DB::ActionsDAG::updateHeader(DB::Block const&) const @ 0x0000000028256e17 14. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:10: DB::ExpressionTransform::transformHeader(DB::Block const&, DB::ActionsDAG const&) @ 0x000000002d9c2197 15. ./build_docker/./src/Processors/QueryPlan/ExpressionStep.cpp:0: DB::ExpressionStep::ExpressionStep(DB::DataStream const&, DB::ActionsDAG) @ 0x000000002dd8d279 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::(anonymous namespace)::addExpressionStep(DB::QueryPlan&, std::shared_ptr&, String const&, std::unordered_set, std::hash>, std::equal_to>, std::allocator>>&) @ 0x000000002943bd73 17. ./contrib/llvm-project/libcxx/include/string:1499: DB::Planner::buildPlanForQueryNode() @ 0x0000000029434460 18. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x00000000294261fb 19. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000029421552 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1182: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3737e 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 27. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 28. asan_thread_start(void*) @ 0x000000000aa43059 29. ? @ 0x00007f35aab92ac3 30. ? @ 0x00007f35aac24850 2025.09.09 14:55:35.474320 [ 4017 ] {0dc75393-691b-434f-95a5-bc3bd47aee49} TCPHandler: Code: 48. DB::Exception: Conditional functions with different Decimal scales. (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aac868e 4. unsigned int DB::(anonymous namespace)::FunctionIf::decimalScale, DB::Decimal>>(std::vector> const&) @ 0x0000000011f04ab5 5. bool DB::callOnBasicType, true, true, true, false, DB::(anonymous namespace)::FunctionIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&)&>(DB::TypeIndex, DB::(anonymous namespace)::FunctionIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&)&) @ 0x0000000011dc3e90 6. DB::(anonymous namespace)::FunctionIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000011c341bf 7. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aa8c635 8. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aac91d5 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000cccccfb 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccce65c 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd2030 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x0000000028259428 13. ./contrib/llvm-project/libcxx/include/vector:961: DB::ActionsDAG::updateHeader(DB::Block const&) const @ 0x0000000028256e17 14. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:10: DB::ExpressionTransform::transformHeader(DB::Block const&, DB::ActionsDAG const&) @ 0x000000002d9c2197 15. ./build_docker/./src/Processors/QueryPlan/ExpressionStep.cpp:0: DB::ExpressionStep::ExpressionStep(DB::DataStream const&, DB::ActionsDAG) @ 0x000000002dd8d279 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::(anonymous namespace)::addExpressionStep(DB::QueryPlan&, std::shared_ptr&, String const&, std::unordered_set, std::hash>, std::equal_to>, std::allocator>>&) @ 0x000000002943bd73 17. ./contrib/llvm-project/libcxx/include/string:1499: DB::Planner::buildPlanForQueryNode() @ 0x0000000029434460 18. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x00000000294261fb 19. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000029421552 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1182: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3737e 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 27. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 28. asan_thread_start(void*) @ 0x000000000aa43059 29. ? @ 0x00007f35aab92ac3 30. ? @ 0x00007f35aac24850 2025.09.09 14:55:35.698727 [ 4017 ] {fa74c50b-ff85-4ecd-a4d0-f393e805bbc7} executeQuery: Code: 48. DB::Exception: Conditional functions with different Decimal scales. (NOT_IMPLEMENTED) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:48476) (comment: 00700_decimal_complex_types.sql) (in query: SELECT number % 2 ? toDecimal64('64.1', 5) : toDecimal32('32.2', 1) FROM system.numbers LIMIT 2;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aac868e 4. unsigned int DB::(anonymous namespace)::FunctionIf::decimalScale, DB::Decimal>(std::vector> const&) @ 0x0000000011f07af5 5. bool DB::callOnBasicType, true, true, true, false, DB::(anonymous namespace)::FunctionIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&)&>(DB::TypeIndex, DB::(anonymous namespace)::FunctionIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&)&) @ 0x0000000011dd42f8 6. DB::(anonymous namespace)::FunctionIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000011c341ae 7. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aa8c635 8. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aac91d5 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000cccccfb 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccce65c 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd2030 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x0000000028259428 13. ./contrib/llvm-project/libcxx/include/vector:961: DB::ActionsDAG::updateHeader(DB::Block const&) const @ 0x0000000028256e17 14. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:10: DB::ExpressionTransform::transformHeader(DB::Block const&, DB::ActionsDAG const&) @ 0x000000002d9c2197 15. ./build_docker/./src/Processors/QueryPlan/ExpressionStep.cpp:0: DB::ExpressionStep::ExpressionStep(DB::DataStream const&, DB::ActionsDAG) @ 0x000000002dd8d279 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::(anonymous namespace)::addExpressionStep(DB::QueryPlan&, std::shared_ptr&, String const&, std::unordered_set, std::hash>, std::equal_to>, std::allocator>>&) @ 0x000000002943bd73 17. ./contrib/llvm-project/libcxx/include/string:1499: DB::Planner::buildPlanForQueryNode() @ 0x0000000029434460 18. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x00000000294261fb 19. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000029421552 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1182: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3737e 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 27. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 28. asan_thread_start(void*) @ 0x000000000aa43059 29. ? @ 0x00007f35aab92ac3 30. ? @ 0x00007f35aac24850 2025.09.09 14:55:35.703472 [ 4017 ] {fa74c50b-ff85-4ecd-a4d0-f393e805bbc7} TCPHandler: Code: 48. DB::Exception: Conditional functions with different Decimal scales. (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aac868e 4. unsigned int DB::(anonymous namespace)::FunctionIf::decimalScale, DB::Decimal>(std::vector> const&) @ 0x0000000011f07af5 5. bool DB::callOnBasicType, true, true, true, false, DB::(anonymous namespace)::FunctionIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&)&>(DB::TypeIndex, DB::(anonymous namespace)::FunctionIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&)&) @ 0x0000000011dd42f8 6. DB::(anonymous namespace)::FunctionIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000011c341ae 7. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aa8c635 8. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aac91d5 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000cccccfb 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccce65c 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd2030 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x0000000028259428 13. ./contrib/llvm-project/libcxx/include/vector:961: DB::ActionsDAG::updateHeader(DB::Block const&) const @ 0x0000000028256e17 14. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:10: DB::ExpressionTransform::transformHeader(DB::Block const&, DB::ActionsDAG const&) @ 0x000000002d9c2197 15. ./build_docker/./src/Processors/QueryPlan/ExpressionStep.cpp:0: DB::ExpressionStep::ExpressionStep(DB::DataStream const&, DB::ActionsDAG) @ 0x000000002dd8d279 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::(anonymous namespace)::addExpressionStep(DB::QueryPlan&, std::shared_ptr&, String const&, std::unordered_set, std::hash>, std::equal_to>, std::allocator>>&) @ 0x000000002943bd73 17. ./contrib/llvm-project/libcxx/include/string:1499: DB::Planner::buildPlanForQueryNode() @ 0x0000000029434460 18. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x00000000294261fb 19. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000029421552 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1182: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3737e 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 27. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 28. asan_thread_start(void*) @ 0x000000000aa43059 29. ? @ 0x00007f35aab92ac3 30. ? @ 0x00007f35aac24850 2025.09.09 14:55:35.885233 [ 5359 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 14:55:35.932993 [ 4017 ] {2be840d0-c18c-454c-918a-a32ca891f033} executeQuery: Code: 48. DB::Exception: Conditional functions with different Decimal scales. (NOT_IMPLEMENTED) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:48476) (comment: 00700_decimal_complex_types.sql) (in query: SELECT number % 2 ? toDecimal64('64.1', 5) : toDecimal64('64.2', 2) FROM system.numbers LIMIT 2;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aac868e 4. unsigned int DB::(anonymous namespace)::FunctionIf::decimalScale, DB::Decimal>(std::vector> const&) @ 0x0000000011f08d15 5. bool DB::callOnBasicType, true, true, true, false, DB::(anonymous namespace)::FunctionIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&)&>(DB::TypeIndex, DB::(anonymous namespace)::FunctionIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&)&) @ 0x0000000011dd4241 6. DB::(anonymous namespace)::FunctionIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000011c341ae 7. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aa8c635 8. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aac91d5 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000cccccfb 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccce65c 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd2030 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x0000000028259428 13. ./contrib/llvm-project/libcxx/include/vector:961: DB::ActionsDAG::updateHeader(DB::Block const&) const @ 0x0000000028256e17 14. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:10: DB::ExpressionTransform::transformHeader(DB::Block const&, DB::ActionsDAG const&) @ 0x000000002d9c2197 15. ./build_docker/./src/Processors/QueryPlan/ExpressionStep.cpp:0: DB::ExpressionStep::ExpressionStep(DB::DataStream const&, DB::ActionsDAG) @ 0x000000002dd8d279 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::(anonymous namespace)::addExpressionStep(DB::QueryPlan&, std::shared_ptr&, String const&, std::unordered_set, std::hash>, std::equal_to>, std::allocator>>&) @ 0x000000002943bd73 17. ./contrib/llvm-project/libcxx/include/string:1499: DB::Planner::buildPlanForQueryNode() @ 0x0000000029434460 18. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x00000000294261fb 19. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000029421552 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1182: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3737e 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 27. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 28. asan_thread_start(void*) @ 0x000000000aa43059 29. ? @ 0x00007f35aab92ac3 30. ? @ 0x00007f35aac24850 2025.09.09 14:55:35.935647 [ 4017 ] {2be840d0-c18c-454c-918a-a32ca891f033} TCPHandler: Code: 48. DB::Exception: Conditional functions with different Decimal scales. (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aac868e 4. unsigned int DB::(anonymous namespace)::FunctionIf::decimalScale, DB::Decimal>(std::vector> const&) @ 0x0000000011f08d15 5. bool DB::callOnBasicType, true, true, true, false, DB::(anonymous namespace)::FunctionIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&)&>(DB::TypeIndex, DB::(anonymous namespace)::FunctionIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&)&) @ 0x0000000011dd4241 6. DB::(anonymous namespace)::FunctionIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000011c341ae 7. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aa8c635 8. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aac91d5 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000cccccfb 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccce65c 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd2030 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x0000000028259428 13. ./contrib/llvm-project/libcxx/include/vector:961: DB::ActionsDAG::updateHeader(DB::Block const&) const @ 0x0000000028256e17 14. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:10: DB::ExpressionTransform::transformHeader(DB::Block const&, DB::ActionsDAG const&) @ 0x000000002d9c2197 15. ./build_docker/./src/Processors/QueryPlan/ExpressionStep.cpp:0: DB::ExpressionStep::ExpressionStep(DB::DataStream const&, DB::ActionsDAG) @ 0x000000002dd8d279 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::(anonymous namespace)::addExpressionStep(DB::QueryPlan&, std::shared_ptr&, String const&, std::unordered_set, std::hash>, std::equal_to>, std::allocator>>&) @ 0x000000002943bd73 17. ./contrib/llvm-project/libcxx/include/string:1499: DB::Planner::buildPlanForQueryNode() @ 0x0000000029434460 18. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x00000000294261fb 19. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000029421552 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1182: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3737e 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 27. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 28. asan_thread_start(void*) @ 0x000000000aa43059 29. ? @ 0x00007f35aab92ac3 30. ? @ 0x00007f35aac24850 2025.09.09 14:55:36.134811 [ 2830 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:55:36.142603 [ 4017 ] {bc0a9ace-427d-4754-b557-8a8705d8fe00} executeQuery: Code: 48. DB::Exception: Conditional functions with different Decimal scales. (NOT_IMPLEMENTED) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:48476) (comment: 00700_decimal_complex_types.sql) (in query: SELECT number % 2 ? toDecimal64('64.1', 5) : toDecimal128('128.2', 3) FROM system.numbers LIMIT 2;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aac868e 4. unsigned int DB::(anonymous namespace)::FunctionIf::decimalScale, DB::Decimal>>(std::vector> const&) @ 0x0000000011f09f35 5. bool DB::callOnBasicType, true, true, true, false, DB::(anonymous namespace)::FunctionIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&)&>(DB::TypeIndex, DB::(anonymous namespace)::FunctionIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&)&) @ 0x0000000011dd3a81 6. DB::(anonymous namespace)::FunctionIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000011c341ae 7. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aa8c635 8. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aac91d5 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000cccccfb 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccce65c 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd2030 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x0000000028259428 13. ./contrib/llvm-project/libcxx/include/vector:961: DB::ActionsDAG::updateHeader(DB::Block const&) const @ 0x0000000028256e17 14. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:10: DB::ExpressionTransform::transformHeader(DB::Block const&, DB::ActionsDAG const&) @ 0x000000002d9c2197 15. ./build_docker/./src/Processors/QueryPlan/ExpressionStep.cpp:0: DB::ExpressionStep::ExpressionStep(DB::DataStream const&, DB::ActionsDAG) @ 0x000000002dd8d279 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::(anonymous namespace)::addExpressionStep(DB::QueryPlan&, std::shared_ptr&, String const&, std::unordered_set, std::hash>, std::equal_to>, std::allocator>>&) @ 0x000000002943bd73 17. ./contrib/llvm-project/libcxx/include/string:1499: DB::Planner::buildPlanForQueryNode() @ 0x0000000029434460 18. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x00000000294261fb 19. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000029421552 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1182: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3737e 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 27. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 28. asan_thread_start(void*) @ 0x000000000aa43059 29. ? @ 0x00007f35aab92ac3 30. ? @ 0x00007f35aac24850 2025.09.09 14:55:36.145059 [ 2832 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:55:36.145397 [ 4017 ] {bc0a9ace-427d-4754-b557-8a8705d8fe00} TCPHandler: Code: 48. DB::Exception: Conditional functions with different Decimal scales. (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aac868e 4. unsigned int DB::(anonymous namespace)::FunctionIf::decimalScale, DB::Decimal>>(std::vector> const&) @ 0x0000000011f09f35 5. bool DB::callOnBasicType, true, true, true, false, DB::(anonymous namespace)::FunctionIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&)&>(DB::TypeIndex, DB::(anonymous namespace)::FunctionIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&)&) @ 0x0000000011dd3a81 6. DB::(anonymous namespace)::FunctionIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000011c341ae 7. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aa8c635 8. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aac91d5 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000cccccfb 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccce65c 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd2030 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x0000000028259428 13. ./contrib/llvm-project/libcxx/include/vector:961: DB::ActionsDAG::updateHeader(DB::Block const&) const @ 0x0000000028256e17 14. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:10: DB::ExpressionTransform::transformHeader(DB::Block const&, DB::ActionsDAG const&) @ 0x000000002d9c2197 15. ./build_docker/./src/Processors/QueryPlan/ExpressionStep.cpp:0: DB::ExpressionStep::ExpressionStep(DB::DataStream const&, DB::ActionsDAG) @ 0x000000002dd8d279 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::(anonymous namespace)::addExpressionStep(DB::QueryPlan&, std::shared_ptr&, String const&, std::unordered_set, std::hash>, std::equal_to>, std::allocator>>&) @ 0x000000002943bd73 17. ./contrib/llvm-project/libcxx/include/string:1499: DB::Planner::buildPlanForQueryNode() @ 0x0000000029434460 18. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x00000000294261fb 19. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000029421552 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1182: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3737e 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 27. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 28. asan_thread_start(void*) @ 0x000000000aa43059 29. ? @ 0x00007f35aab92ac3 30. ? @ 0x00007f35aac24850 2025.09.09 14:55:36.256323 [ 4022 ] {76d2525e-2a80-4632-99d6-faf64f860eda} executeQuery: Code: 48. DB::Exception: Truncate is not supported by storage Merge. (NOT_IMPLEMENTED) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:39600) (comment: 01436_storage_merge_with_join_push_down.sql) (in query: DROP TABLE test_merge;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::IStorage::truncate(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, DB::TableExclusiveLockHolder&) @ 0x00000000260e9270 4. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:279: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x00000000291f066f 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x00000000291ed665 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x00000000291ebd68 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x00000000291eb7ed 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b382fc 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 11. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 15. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 16. asan_thread_start(void*) @ 0x000000000aa43059 17. ? @ 0x00007f35aab92ac3 18. ? @ 0x00007f35aac24850 2025.09.09 14:55:36.259429 [ 4022 ] {76d2525e-2a80-4632-99d6-faf64f860eda} 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::IStorage::truncate(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, DB::TableExclusiveLockHolder&) @ 0x00000000260e9270 4. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:279: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x00000000291f066f 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x00000000291ed665 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x00000000291ebd68 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x00000000291eb7ed 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b382fc 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 11. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 15. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 16. asan_thread_start(void*) @ 0x000000000aa43059 17. ? @ 0x00007f35aab92ac3 18. ? @ 0x00007f35aac24850 2025.09.09 14:55:36.478894 [ 4017 ] {67cd21e1-c045-4633-9bdc-8f48f42c93bf} executeQuery: Code: 48. DB::Exception: Conditional functions with different Decimal scales. (NOT_IMPLEMENTED) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:48476) (comment: 00700_decimal_complex_types.sql) (in query: SELECT number % 2 ? toDecimal128('128.1', 5) : toDecimal32('32.2', 1) FROM system.numbers LIMIT 2;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aac868e 4. unsigned int DB::(anonymous namespace)::FunctionIf::decimalScale>, DB::Decimal>(std::vector> const&) @ 0x0000000011f0cf75 5. bool DB::callOnBasicType>, true, true, true, false, DB::(anonymous namespace)::FunctionIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&)&>(DB::TypeIndex, DB::(anonymous namespace)::FunctionIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&)&) @ 0x0000000011de38a1 6. DB::(anonymous namespace)::FunctionIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000011c3409c 7. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aa8c635 8. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aac91d5 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000cccccfb 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccce65c 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd2030 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x0000000028259428 13. ./contrib/llvm-project/libcxx/include/vector:961: DB::ActionsDAG::updateHeader(DB::Block const&) const @ 0x0000000028256e17 14. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:10: DB::ExpressionTransform::transformHeader(DB::Block const&, DB::ActionsDAG const&) @ 0x000000002d9c2197 15. ./build_docker/./src/Processors/QueryPlan/ExpressionStep.cpp:0: DB::ExpressionStep::ExpressionStep(DB::DataStream const&, DB::ActionsDAG) @ 0x000000002dd8d279 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::(anonymous namespace)::addExpressionStep(DB::QueryPlan&, std::shared_ptr&, String const&, std::unordered_set, std::hash>, std::equal_to>, std::allocator>>&) @ 0x000000002943bd73 17. ./contrib/llvm-project/libcxx/include/string:1499: DB::Planner::buildPlanForQueryNode() @ 0x0000000029434460 18. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x00000000294261fb 19. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000029421552 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1182: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3737e 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 27. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 28. asan_thread_start(void*) @ 0x000000000aa43059 29. ? @ 0x00007f35aab92ac3 30. ? @ 0x00007f35aac24850 2025.09.09 14:55:36.487957 [ 4017 ] {67cd21e1-c045-4633-9bdc-8f48f42c93bf} TCPHandler: Code: 48. DB::Exception: Conditional functions with different Decimal scales. (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aac868e 4. unsigned int DB::(anonymous namespace)::FunctionIf::decimalScale>, DB::Decimal>(std::vector> const&) @ 0x0000000011f0cf75 5. bool DB::callOnBasicType>, true, true, true, false, DB::(anonymous namespace)::FunctionIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&)&>(DB::TypeIndex, DB::(anonymous namespace)::FunctionIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&)&) @ 0x0000000011de38a1 6. DB::(anonymous namespace)::FunctionIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000011c3409c 7. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aa8c635 8. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aac91d5 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000cccccfb 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccce65c 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd2030 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x0000000028259428 13. ./contrib/llvm-project/libcxx/include/vector:961: DB::ActionsDAG::updateHeader(DB::Block const&) const @ 0x0000000028256e17 14. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:10: DB::ExpressionTransform::transformHeader(DB::Block const&, DB::ActionsDAG const&) @ 0x000000002d9c2197 15. ./build_docker/./src/Processors/QueryPlan/ExpressionStep.cpp:0: DB::ExpressionStep::ExpressionStep(DB::DataStream const&, DB::ActionsDAG) @ 0x000000002dd8d279 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::(anonymous namespace)::addExpressionStep(DB::QueryPlan&, std::shared_ptr&, String const&, std::unordered_set, std::hash>, std::equal_to>, std::allocator>>&) @ 0x000000002943bd73 17. ./contrib/llvm-project/libcxx/include/string:1499: DB::Planner::buildPlanForQueryNode() @ 0x0000000029434460 18. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x00000000294261fb 19. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000029421552 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1182: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3737e 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 27. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 28. asan_thread_start(void*) @ 0x000000000aa43059 29. ? @ 0x00007f35aab92ac3 30. ? @ 0x00007f35aac24850 2025.09.09 14:55:36.830907 [ 5359 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 14:55:36.865251 [ 4017 ] {5d78b447-756d-462a-a152-2d2c35e9b790} executeQuery: Code: 48. DB::Exception: Conditional functions with different Decimal scales. (NOT_IMPLEMENTED) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:48476) (comment: 00700_decimal_complex_types.sql) (in query: SELECT number % 2 ? toDecimal128('128.1', 5) : toDecimal64('64.2', 2) FROM system.numbers LIMIT 2;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aac868e 4. unsigned int DB::(anonymous namespace)::FunctionIf::decimalScale>, DB::Decimal>(std::vector> const&) @ 0x0000000011f0e195 5. bool DB::callOnBasicType>, true, true, true, false, DB::(anonymous namespace)::FunctionIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&)&>(DB::TypeIndex, DB::(anonymous namespace)::FunctionIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&)&) @ 0x0000000011de343a 6. DB::(anonymous namespace)::FunctionIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000011c3409c 7. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aa8c635 8. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aac91d5 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000cccccfb 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccce65c 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd2030 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x0000000028259428 13. ./contrib/llvm-project/libcxx/include/vector:961: DB::ActionsDAG::updateHeader(DB::Block const&) const @ 0x0000000028256e17 14. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:10: DB::ExpressionTransform::transformHeader(DB::Block const&, DB::ActionsDAG const&) @ 0x000000002d9c2197 15. ./build_docker/./src/Processors/QueryPlan/ExpressionStep.cpp:0: DB::ExpressionStep::ExpressionStep(DB::DataStream const&, DB::ActionsDAG) @ 0x000000002dd8d279 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::(anonymous namespace)::addExpressionStep(DB::QueryPlan&, std::shared_ptr&, String const&, std::unordered_set, std::hash>, std::equal_to>, std::allocator>>&) @ 0x000000002943bd73 17. ./contrib/llvm-project/libcxx/include/string:1499: DB::Planner::buildPlanForQueryNode() @ 0x0000000029434460 18. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x00000000294261fb 19. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000029421552 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1182: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3737e 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 27. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 28. asan_thread_start(void*) @ 0x000000000aa43059 29. ? @ 0x00007f35aab92ac3 30. ? @ 0x00007f35aac24850 2025.09.09 14:55:36.867370 [ 4017 ] {5d78b447-756d-462a-a152-2d2c35e9b790} TCPHandler: Code: 48. DB::Exception: Conditional functions with different Decimal scales. (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aac868e 4. unsigned int DB::(anonymous namespace)::FunctionIf::decimalScale>, DB::Decimal>(std::vector> const&) @ 0x0000000011f0e195 5. bool DB::callOnBasicType>, true, true, true, false, DB::(anonymous namespace)::FunctionIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&)&>(DB::TypeIndex, DB::(anonymous namespace)::FunctionIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&)&) @ 0x0000000011de343a 6. DB::(anonymous namespace)::FunctionIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000011c3409c 7. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aa8c635 8. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aac91d5 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000cccccfb 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccce65c 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd2030 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x0000000028259428 13. ./contrib/llvm-project/libcxx/include/vector:961: DB::ActionsDAG::updateHeader(DB::Block const&) const @ 0x0000000028256e17 14. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:10: DB::ExpressionTransform::transformHeader(DB::Block const&, DB::ActionsDAG const&) @ 0x000000002d9c2197 15. ./build_docker/./src/Processors/QueryPlan/ExpressionStep.cpp:0: DB::ExpressionStep::ExpressionStep(DB::DataStream const&, DB::ActionsDAG) @ 0x000000002dd8d279 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::(anonymous namespace)::addExpressionStep(DB::QueryPlan&, std::shared_ptr&, String const&, std::unordered_set, std::hash>, std::equal_to>, std::allocator>>&) @ 0x000000002943bd73 17. ./contrib/llvm-project/libcxx/include/string:1499: DB::Planner::buildPlanForQueryNode() @ 0x0000000029434460 18. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x00000000294261fb 19. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000029421552 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1182: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3737e 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 27. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 28. asan_thread_start(void*) @ 0x000000000aa43059 29. ? @ 0x00007f35aab92ac3 30. ? @ 0x00007f35aac24850 2025.09.09 14:55:37.119437 [ 4017 ] {5b2fde46-d471-45d9-8bbc-12471def26e9} executeQuery: Code: 48. DB::Exception: Conditional functions with different Decimal scales. (NOT_IMPLEMENTED) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:48476) (comment: 00700_decimal_complex_types.sql) (in query: SELECT number % 2 ? toDecimal128('128.1', 5) : toDecimal128('128.2', 3) FROM system.numbers LIMIT 2;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aac868e 4. unsigned int DB::(anonymous namespace)::FunctionIf::decimalScale>, DB::Decimal>>(std::vector> const&) @ 0x0000000011f0f3b5 5. bool DB::callOnBasicType>, true, true, true, false, DB::(anonymous namespace)::FunctionIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&)&>(DB::TypeIndex, DB::(anonymous namespace)::FunctionIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&)&) @ 0x0000000011de2f79 6. DB::(anonymous namespace)::FunctionIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000011c3409c 7. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aa8c635 8. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aac91d5 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000cccccfb 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccce65c 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd2030 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x0000000028259428 13. ./contrib/llvm-project/libcxx/include/vector:961: DB::ActionsDAG::updateHeader(DB::Block const&) const @ 0x0000000028256e17 14. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:10: DB::ExpressionTransform::transformHeader(DB::Block const&, DB::ActionsDAG const&) @ 0x000000002d9c2197 15. ./build_docker/./src/Processors/QueryPlan/ExpressionStep.cpp:0: DB::ExpressionStep::ExpressionStep(DB::DataStream const&, DB::ActionsDAG) @ 0x000000002dd8d279 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::(anonymous namespace)::addExpressionStep(DB::QueryPlan&, std::shared_ptr&, String const&, std::unordered_set, std::hash>, std::equal_to>, std::allocator>>&) @ 0x000000002943bd73 17. ./contrib/llvm-project/libcxx/include/string:1499: DB::Planner::buildPlanForQueryNode() @ 0x0000000029434460 18. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x00000000294261fb 19. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000029421552 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1182: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3737e 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 27. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 28. asan_thread_start(void*) @ 0x000000000aa43059 29. ? @ 0x00007f35aab92ac3 30. ? @ 0x00007f35aac24850 2025.09.09 14:55:37.122963 [ 4017 ] {5b2fde46-d471-45d9-8bbc-12471def26e9} TCPHandler: Code: 48. DB::Exception: Conditional functions with different Decimal scales. (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aac868e 4. unsigned int DB::(anonymous namespace)::FunctionIf::decimalScale>, DB::Decimal>>(std::vector> const&) @ 0x0000000011f0f3b5 5. bool DB::callOnBasicType>, true, true, true, false, DB::(anonymous namespace)::FunctionIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&)&>(DB::TypeIndex, DB::(anonymous namespace)::FunctionIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&)&) @ 0x0000000011de2f79 6. DB::(anonymous namespace)::FunctionIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000011c3409c 7. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aa8c635 8. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aac91d5 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000cccccfb 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccce65c 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd2030 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x0000000028259428 13. ./contrib/llvm-project/libcxx/include/vector:961: DB::ActionsDAG::updateHeader(DB::Block const&) const @ 0x0000000028256e17 14. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:10: DB::ExpressionTransform::transformHeader(DB::Block const&, DB::ActionsDAG const&) @ 0x000000002d9c2197 15. ./build_docker/./src/Processors/QueryPlan/ExpressionStep.cpp:0: DB::ExpressionStep::ExpressionStep(DB::DataStream const&, DB::ActionsDAG) @ 0x000000002dd8d279 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::(anonymous namespace)::addExpressionStep(DB::QueryPlan&, std::shared_ptr&, String const&, std::unordered_set, std::hash>, std::equal_to>, std::allocator>>&) @ 0x000000002943bd73 17. ./contrib/llvm-project/libcxx/include/string:1499: DB::Planner::buildPlanForQueryNode() @ 0x0000000029434460 18. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x00000000294261fb 19. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000029421552 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1182: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3737e 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 27. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 28. asan_thread_start(void*) @ 0x000000000aa43059 29. ? @ 0x00007f35aab92ac3 30. ? @ 0x00007f35aac24850 2025.09.09 14:55:37.136779 [ 2833 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:55:37.146941 [ 2835 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:55:37.808887 [ 5359 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 14:55:38.138727 [ 2852 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:55:38.149169 [ 2854 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:55:38.814377 [ 5359 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 14:55:39.140753 [ 2863 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:55:39.151322 [ 2873 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:55:39.817618 [ 5359 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 14:55:40.144630 [ 2882 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:55:40.155961 [ 2891 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:55:40.775182 [ 5359 ] {a7c35664-f964-40f7-9e13-c48eb73f2eeb} executeQuery: Code: 582. DB::Exception: There is no projection pToDro in table. Maybe you meant: ['pToDrop']. (NO_SUCH_PROJECTION_IN_TABLE) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:51182) (comment: 02250_hints_for_projections.sh) (in query: ALTER TABLE t DROP PROJECTION pToDro), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000c44a97a 4. ./build_docker/./src/Storages/ProjectionsDescription.cpp:408: DB::ProjectionsDescription::remove(String const&, bool) @ 0x000000002b6f061a 5. ./build_docker/./src/Storages/AlterCommands.cpp:797: DB::AlterCommand::apply(DB::StorageInMemoryMetadata&, std::shared_ptr) const @ 0x000000002b5effed 6. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::AlterCommands::apply(DB::StorageInMemoryMetadata&, std::shared_ptr) const @ 0x000000002b5fe5bc 7. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x000000002c492570 8. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000029174532 9. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x0000000029170711 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b382fc 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 13. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 18. asan_thread_start(void*) @ 0x000000000aa43059 19. ? @ 0x00007f35aab92ac3 20. ? @ 0x00007f35aac24850 2025.09.09 14:55:40.796694 [ 5359 ] {a7c35664-f964-40f7-9e13-c48eb73f2eeb} TCPHandler: Code: 582. DB::Exception: There is no projection pToDro in table. Maybe you meant: ['pToDrop']. (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000c44a97a 4. ./build_docker/./src/Storages/ProjectionsDescription.cpp:408: DB::ProjectionsDescription::remove(String const&, bool) @ 0x000000002b6f061a 5. ./build_docker/./src/Storages/AlterCommands.cpp:797: DB::AlterCommand::apply(DB::StorageInMemoryMetadata&, std::shared_ptr) const @ 0x000000002b5effed 6. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::AlterCommands::apply(DB::StorageInMemoryMetadata&, std::shared_ptr) const @ 0x000000002b5fe5bc 7. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x000000002c492570 8. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000029174532 9. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x0000000029170711 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b382fc 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 13. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 18. asan_thread_start(void*) @ 0x000000000aa43059 19. ? @ 0x00007f35aab92ac3 20. ? @ 0x00007f35aac24850 2025.09.09 14:55:40.838013 [ 4019 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 14:55:41.147154 [ 2905 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:55:41.158398 [ 2915 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:55:41.950901 [ 5359 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 14:55:42.149103 [ 2928 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:55:42.160532 [ 2934 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:55:42.999689 [ 4022 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 14:55:43.151270 [ 2949 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:55:43.162596 [ 2957 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:55:44.048732 [ 5359 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 14:55:44.153630 [ 2975 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:55:44.164783 [ 2970 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:55:44.793053 [ 5359 ] {40dbd5e3-de5b-426b-8e88-ba9459327fea} executeQuery: Code: 43. DB::Exception: Illegal type Dynamic of argument of aggregate function max because the column of that type can contain values with different data types. Consider using typed subcolumns or cast column to a specific data type. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:51276) (comment: 03271_dynamic_variant_in_min_max.sql) (in query: select max(number::Dynamic) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa91e9a 4. ./build_docker/./src/AggregateFunctions/AggregateFunctionsMinMax.cpp:40: _ZN2DBL34createAggregateFunctionSingleValueITtTyTpTnbENS_12_GLOBAL__N_123AggregateFunctionMinMaxELb1EJLb0EEEEPNS_18IAggregateFunctionERKNSt3__112basic_stringIcNS5_11char_traitsIcEENS5_9allocatorIcEEEERKNS5_6vectorINS5_10shared_ptrIKNS_9IDataTypeEEENS9_ISI_EEEERKNS_5ArrayEPKNS_8SettingsE @ 0x0000000023d9664d 5. ./build_docker/./src/AggregateFunctions/AggregateFunctionsMinMax.cpp:200: std::shared_ptr DB::(anonymous namespace)::createAggregateFunctionMinMax(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x0000000023d57629 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000265b499e 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 @ 0x00000000265b1c12 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002839a287 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000028367bce 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028366290 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283b62c9 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002835ae03 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000028359104 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000028357f0d 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002921bdcc 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&) @ 0x000000002941f313 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&) @ 0x0000000029419aef 18. ./contrib/llvm-project/libcxx/include/vector:432: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000029421f5d 19. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000029344c1b 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*) @ 0x0000000029b3703b 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 27. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 28. asan_thread_start(void*) @ 0x000000000aa43059 29. ? @ 0x00007f35aab92ac3 30. ? @ 0x00007f35aac24850 2025.09.09 14:55:44.795207 [ 5359 ] {40dbd5e3-de5b-426b-8e88-ba9459327fea} TCPHandler: Code: 43. DB::Exception: Illegal type Dynamic of argument of aggregate function max because the column of that type can contain values with different data types. Consider using typed subcolumns or cast column to a specific data type. (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa91e9a 4. ./build_docker/./src/AggregateFunctions/AggregateFunctionsMinMax.cpp:40: _ZN2DBL34createAggregateFunctionSingleValueITtTyTpTnbENS_12_GLOBAL__N_123AggregateFunctionMinMaxELb1EJLb0EEEEPNS_18IAggregateFunctionERKNSt3__112basic_stringIcNS5_11char_traitsIcEENS5_9allocatorIcEEEERKNS5_6vectorINS5_10shared_ptrIKNS_9IDataTypeEEENS9_ISI_EEEERKNS_5ArrayEPKNS_8SettingsE @ 0x0000000023d9664d 5. ./build_docker/./src/AggregateFunctions/AggregateFunctionsMinMax.cpp:200: std::shared_ptr DB::(anonymous namespace)::createAggregateFunctionMinMax(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x0000000023d57629 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000265b499e 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 @ 0x00000000265b1c12 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002839a287 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000028367bce 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028366290 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283b62c9 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002835ae03 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000028359104 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000028357f0d 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002921bdcc 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&) @ 0x000000002941f313 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&) @ 0x0000000029419aef 18. ./contrib/llvm-project/libcxx/include/vector:432: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000029421f5d 19. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000029344c1b 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*) @ 0x0000000029b3703b 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 27. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 28. asan_thread_start(void*) @ 0x000000000aa43059 29. ? @ 0x00007f35aab92ac3 30. ? @ 0x00007f35aac24850 2025.09.09 14:55:44.971532 [ 5359 ] {037e30ea-7245-4167-b7bb-45305eae98e7} executeQuery: Code: 43. DB::Exception: Illegal type Dynamic of argument of aggregate function min because the column of that type can contain values with different data types. Consider using typed subcolumns or cast column to a specific data type. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:51276) (comment: 03271_dynamic_variant_in_min_max.sql) (in query: select min(number::Dynamic) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa91e9a 4. ./build_docker/./src/AggregateFunctions/AggregateFunctionsMinMax.cpp:40: _ZN2DBL34createAggregateFunctionSingleValueITtTyTpTnbENS_12_GLOBAL__N_123AggregateFunctionMinMaxELb1EJLb1EEEEPNS_18IAggregateFunctionERKNSt3__112basic_stringIcNS5_11char_traitsIcEENS5_9allocatorIcEEEERKNS5_6vectorINS5_10shared_ptrIKNS_9IDataTypeEEENS9_ISI_EEEERKNS_5ArrayEPKNS_8SettingsE @ 0x0000000023d5da8d 5. ./build_docker/./src/AggregateFunctions/AggregateFunctionsMinMax.cpp:200: std::shared_ptr DB::(anonymous namespace)::createAggregateFunctionMinMax(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x0000000023d57369 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000265b499e 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 @ 0x00000000265b1c12 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002839a287 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000028367bce 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028366290 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283b62c9 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002835ae03 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000028359104 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000028357f0d 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002921bdcc 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&) @ 0x000000002941f313 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&) @ 0x0000000029419aef 18. ./contrib/llvm-project/libcxx/include/vector:432: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000029421f5d 19. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000029344c1b 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*) @ 0x0000000029b3703b 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 27. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 28. asan_thread_start(void*) @ 0x000000000aa43059 29. ? @ 0x00007f35aab92ac3 30. ? @ 0x00007f35aac24850 2025.09.09 14:55:44.974144 [ 5359 ] {037e30ea-7245-4167-b7bb-45305eae98e7} TCPHandler: Code: 43. DB::Exception: Illegal type Dynamic of argument of aggregate function min because the column of that type can contain values with different data types. Consider using typed subcolumns or cast column to a specific data type. (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa91e9a 4. ./build_docker/./src/AggregateFunctions/AggregateFunctionsMinMax.cpp:40: _ZN2DBL34createAggregateFunctionSingleValueITtTyTpTnbENS_12_GLOBAL__N_123AggregateFunctionMinMaxELb1EJLb1EEEEPNS_18IAggregateFunctionERKNSt3__112basic_stringIcNS5_11char_traitsIcEENS5_9allocatorIcEEEERKNS5_6vectorINS5_10shared_ptrIKNS_9IDataTypeEEENS9_ISI_EEEERKNS_5ArrayEPKNS_8SettingsE @ 0x0000000023d5da8d 5. ./build_docker/./src/AggregateFunctions/AggregateFunctionsMinMax.cpp:200: std::shared_ptr DB::(anonymous namespace)::createAggregateFunctionMinMax(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x0000000023d57369 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000265b499e 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 @ 0x00000000265b1c12 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002839a287 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000028367bce 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028366290 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283b62c9 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002835ae03 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000028359104 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000028357f0d 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002921bdcc 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&) @ 0x000000002941f313 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&) @ 0x0000000029419aef 18. ./contrib/llvm-project/libcxx/include/vector:432: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000029421f5d 19. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000029344c1b 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*) @ 0x0000000029b3703b 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 27. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 28. asan_thread_start(void*) @ 0x000000000aa43059 29. ? @ 0x00007f35aab92ac3 30. ? @ 0x00007f35aac24850 2025.09.09 14:55:44.993013 [ 4019 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 14:55:45.087106 [ 5359 ] {d173d350-cd01-4991-8ddc-259be5d1dfd9} executeQuery: Code: 43. DB::Exception: Illegal type Dynamic of argument of aggregate function argMax because the column of that type can contain values with different data types. Consider using typed subcolumns or cast column to a specific data type. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:51276) (comment: 03271_dynamic_variant_in_min_max.sql) (in query: select argMax(number, number::Dynamic) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa91e9a 4. ./build_docker/./src/AggregateFunctions/AggregateFunctionsArgMinArgMax.cpp:84: _ZN2DBL34createAggregateFunctionSingleValueITtTyTpTnbENS_12_GLOBAL__N_126AggregateFunctionArgMinMaxELb0EJLb0EEEEPNS_18IAggregateFunctionERKNSt3__112basic_stringIcNS5_11char_traitsIcEENS5_9allocatorIcEEEERKNS5_6vectorINS5_10shared_ptrIKNS_9IDataTypeEEENS9_ISI_EEEERKNS_5ArrayEPKNS_8SettingsE @ 0x0000000023f3ac96 5. ./build_docker/./src/AggregateFunctions/AggregateFunctionsArgMinArgMax.cpp:231: std::shared_ptr DB::(anonymous namespace)::createAggregateFunctionArgMinMax(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x0000000023ed84c9 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000265b499e 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 @ 0x00000000265b1c12 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002839a287 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000028367bce 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028366290 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283b62c9 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002835ae03 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000028359104 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000028357f0d 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002921bdcc 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&) @ 0x000000002941f313 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&) @ 0x0000000029419aef 18. ./contrib/llvm-project/libcxx/include/vector:432: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000029421f5d 19. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000029344c1b 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*) @ 0x0000000029b3703b 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 27. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 28. asan_thread_start(void*) @ 0x000000000aa43059 29. ? @ 0x00007f35aab92ac3 30. ? @ 0x00007f35aac24850 2025.09.09 14:55:45.089375 [ 5359 ] {d173d350-cd01-4991-8ddc-259be5d1dfd9} TCPHandler: Code: 43. DB::Exception: Illegal type Dynamic of argument of aggregate function argMax because the column of that type can contain values with different data types. Consider using typed subcolumns or cast column to a specific data type. (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa91e9a 4. ./build_docker/./src/AggregateFunctions/AggregateFunctionsArgMinArgMax.cpp:84: _ZN2DBL34createAggregateFunctionSingleValueITtTyTpTnbENS_12_GLOBAL__N_126AggregateFunctionArgMinMaxELb0EJLb0EEEEPNS_18IAggregateFunctionERKNSt3__112basic_stringIcNS5_11char_traitsIcEENS5_9allocatorIcEEEERKNS5_6vectorINS5_10shared_ptrIKNS_9IDataTypeEEENS9_ISI_EEEERKNS_5ArrayEPKNS_8SettingsE @ 0x0000000023f3ac96 5. ./build_docker/./src/AggregateFunctions/AggregateFunctionsArgMinArgMax.cpp:231: std::shared_ptr DB::(anonymous namespace)::createAggregateFunctionArgMinMax(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x0000000023ed84c9 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000265b499e 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 @ 0x00000000265b1c12 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002839a287 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000028367bce 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028366290 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283b62c9 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002835ae03 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000028359104 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000028357f0d 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002921bdcc 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&) @ 0x000000002941f313 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&) @ 0x0000000029419aef 18. ./contrib/llvm-project/libcxx/include/vector:432: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000029421f5d 19. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000029344c1b 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*) @ 0x0000000029b3703b 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 27. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 28. asan_thread_start(void*) @ 0x000000000aa43059 29. ? @ 0x00007f35aab92ac3 30. ? @ 0x00007f35aac24850 2025.09.09 14:55:45.155543 [ 2993 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:55:45.167047 [ 2995 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:55:45.338288 [ 5359 ] {05ad7761-df5a-430f-b1de-9d4b4ff627c6} executeQuery: Code: 43. DB::Exception: Illegal type Dynamic of argument of aggregate function argMin because the column of that type can contain values with different data types. Consider using typed subcolumns or cast column to a specific data type. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:51276) (comment: 03271_dynamic_variant_in_min_max.sql) (in query: select argMin(number, number::Dynamic) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa91e9a 4. ./build_docker/./src/AggregateFunctions/AggregateFunctionsArgMinArgMax.cpp:84: _ZN2DBL34createAggregateFunctionSingleValueITtTyTpTnbENS_12_GLOBAL__N_126AggregateFunctionArgMinMaxELb0EJLb1EEEEPNS_18IAggregateFunctionERKNSt3__112basic_stringIcNS5_11char_traitsIcEENS5_9allocatorIcEEEERKNS5_6vectorINS5_10shared_ptrIKNS_9IDataTypeEEENS9_ISI_EEEERKNS_5ArrayEPKNS_8SettingsE @ 0x0000000023ee0776 5. ./build_docker/./src/AggregateFunctions/AggregateFunctionsArgMinArgMax.cpp:231: std::shared_ptr DB::(anonymous namespace)::createAggregateFunctionArgMinMax(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x0000000023ed8209 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000265b499e 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 @ 0x00000000265b1c12 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002839a287 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000028367bce 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028366290 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283b62c9 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002835ae03 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000028359104 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000028357f0d 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002921bdcc 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&) @ 0x000000002941f313 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&) @ 0x0000000029419aef 18. ./contrib/llvm-project/libcxx/include/vector:432: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000029421f5d 19. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000029344c1b 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*) @ 0x0000000029b3703b 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 27. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 28. asan_thread_start(void*) @ 0x000000000aa43059 29. ? @ 0x00007f35aab92ac3 30. ? @ 0x00007f35aac24850 2025.09.09 14:55:45.340519 [ 5359 ] {05ad7761-df5a-430f-b1de-9d4b4ff627c6} TCPHandler: Code: 43. DB::Exception: Illegal type Dynamic of argument of aggregate function argMin because the column of that type can contain values with different data types. Consider using typed subcolumns or cast column to a specific data type. (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa91e9a 4. ./build_docker/./src/AggregateFunctions/AggregateFunctionsArgMinArgMax.cpp:84: _ZN2DBL34createAggregateFunctionSingleValueITtTyTpTnbENS_12_GLOBAL__N_126AggregateFunctionArgMinMaxELb0EJLb1EEEEPNS_18IAggregateFunctionERKNSt3__112basic_stringIcNS5_11char_traitsIcEENS5_9allocatorIcEEEERKNS5_6vectorINS5_10shared_ptrIKNS_9IDataTypeEEENS9_ISI_EEEERKNS_5ArrayEPKNS_8SettingsE @ 0x0000000023ee0776 5. ./build_docker/./src/AggregateFunctions/AggregateFunctionsArgMinArgMax.cpp:231: std::shared_ptr DB::(anonymous namespace)::createAggregateFunctionArgMinMax(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x0000000023ed8209 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000265b499e 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 @ 0x00000000265b1c12 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002839a287 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000028367bce 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028366290 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283b62c9 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002835ae03 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000028359104 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000028357f0d 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002921bdcc 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&) @ 0x000000002941f313 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&) @ 0x0000000029419aef 18. ./contrib/llvm-project/libcxx/include/vector:432: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000029421f5d 19. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000029344c1b 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*) @ 0x0000000029b3703b 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 27. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 28. asan_thread_start(void*) @ 0x000000000aa43059 29. ? @ 0x00007f35aab92ac3 30. ? @ 0x00007f35aac24850 2025.09.09 14:55:45.573297 [ 4022 ] {1204b4b7-0573-41e3-96e4-bcd301ed4dc3} executeQuery: Code: 277. DB::Exception: Primary key (hilbertEncode(x, y)) is not used and setting 'force_primary_key' is set. (INDEX_NOT_USED) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:51250) (comment: 03171_indexing_by_hilbert_curve.sql) (in query: SELECT count() FROM test_hilbert_encode 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception, std::__wrap_iter, char>>(int, FormatStringHelperImpl, std::__wrap_iter, char>>::type>, fmt::v9::join_view, std::__wrap_iter, char>&&) @ 0x000000002b833a14 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) @ 0x000000002de35ed6 5. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1437: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000002de3554f 6. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:0: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000002de3515e 7. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeUseAggregateProjection.cpp:604: DB::QueryPlanOptimizations::optimizeUseAggregateProjections(DB::QueryPlan::Node&, std::list>&, bool) @ 0x000000002dfa7c7f 8. ./contrib/llvm-project/libcxx/include/optional:344: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x000000002df631d6 9. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:507: DB::QueryPlan::optimize(DB::QueryPlanOptimizationSettings const&) @ 0x000000002de001ca 10. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:36: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000002ddfec4b 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000002942117f 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x00000000294209e7 13. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b382fc 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 16. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 20. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 21. asan_thread_start(void*) @ 0x000000000aa43059 22. ? @ 0x00007f35aab92ac3 23. ? @ 0x00007f35aac24850 2025.09.09 14:55:45.575547 [ 4022 ] {1204b4b7-0573-41e3-96e4-bcd301ed4dc3} TCPHandler: Code: 277. DB::Exception: Primary key (hilbertEncode(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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception, std::__wrap_iter, char>>(int, FormatStringHelperImpl, std::__wrap_iter, char>>::type>, fmt::v9::join_view, std::__wrap_iter, char>&&) @ 0x000000002b833a14 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) @ 0x000000002de35ed6 5. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1437: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000002de3554f 6. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:0: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000002de3515e 7. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeUseAggregateProjection.cpp:604: DB::QueryPlanOptimizations::optimizeUseAggregateProjections(DB::QueryPlan::Node&, std::list>&, bool) @ 0x000000002dfa7c7f 8. ./contrib/llvm-project/libcxx/include/optional:344: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x000000002df631d6 9. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:507: DB::QueryPlan::optimize(DB::QueryPlanOptimizationSettings const&) @ 0x000000002de001ca 10. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:36: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000002ddfec4b 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000002942117f 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x00000000294209e7 13. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b382fc 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 16. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 20. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 21. asan_thread_start(void*) @ 0x000000000aa43059 22. ? @ 0x00007f35aab92ac3 23. ? @ 0x00007f35aac24850 2025.09.09 14:55:45.661186 [ 5359 ] {ad487a0a-d9d9-4da4-b724-c22f2032eb73} executeQuery: Code: 43. DB::Exception: Illegal type Dynamic of argument of aggregate function anyArgMax because the column of that type can contain values with different data types. Consider using typed subcolumns or cast column to a specific data type. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:51276) (comment: 03271_dynamic_variant_in_min_max.sql) (in query: select anyArgMax(number, number::Dynamic) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa91e9a 4. ./build_docker/./src/AggregateFunctions/Combinators/AggregateFunctionCombinatorsArgMinArgMax.cpp:68: DB::(anonymous namespace)::CombinatorArgMinArgMax::transformAggregateFunction(std::shared_ptr const&, DB::AggregateFunctionProperties const&, std::vector, std::allocator>> const&, DB::Array const&) const @ 0x0000000025def7ee 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 @ 0x00000000265b4737 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 @ 0x00000000265b1c12 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002839a287 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000028367bce 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028366290 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283b62c9 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002835ae03 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000028359104 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000028357f0d 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002921bdcc 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&) @ 0x000000002941f313 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&) @ 0x0000000029419aef 17. ./contrib/llvm-project/libcxx/include/vector:432: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000029421f5d 18. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000029344c1b 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*) @ 0x0000000029b3703b 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 21. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 22. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 26. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 27. asan_thread_start(void*) @ 0x000000000aa43059 28. ? @ 0x00007f35aab92ac3 29. ? @ 0x00007f35aac24850 2025.09.09 14:55:45.676297 [ 5359 ] {ad487a0a-d9d9-4da4-b724-c22f2032eb73} TCPHandler: Code: 43. DB::Exception: Illegal type Dynamic of argument of aggregate function anyArgMax because the column of that type can contain values with different data types. Consider using typed subcolumns or cast column to a specific data type. (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa91e9a 4. ./build_docker/./src/AggregateFunctions/Combinators/AggregateFunctionCombinatorsArgMinArgMax.cpp:68: DB::(anonymous namespace)::CombinatorArgMinArgMax::transformAggregateFunction(std::shared_ptr const&, DB::AggregateFunctionProperties const&, std::vector, std::allocator>> const&, DB::Array const&) const @ 0x0000000025def7ee 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 @ 0x00000000265b4737 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 @ 0x00000000265b1c12 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002839a287 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000028367bce 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028366290 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283b62c9 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002835ae03 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000028359104 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000028357f0d 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002921bdcc 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&) @ 0x000000002941f313 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&) @ 0x0000000029419aef 17. ./contrib/llvm-project/libcxx/include/vector:432: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000029421f5d 18. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000029344c1b 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*) @ 0x0000000029b3703b 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 21. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 22. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 26. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 27. asan_thread_start(void*) @ 0x000000000aa43059 28. ? @ 0x00007f35aab92ac3 29. ? @ 0x00007f35aac24850 2025.09.09 14:55:45.926956 [ 5359 ] {31866f52-8554-4fed-8e44-ecb5c8cf420a} executeQuery: Code: 43. DB::Exception: Illegal type Dynamic of argument of aggregate function anyArgMin because the column of that type can contain values with different data types. Consider using typed subcolumns or cast column to a specific data type. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:51276) (comment: 03271_dynamic_variant_in_min_max.sql) (in query: select anyArgMin(number, number::Dynamic) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa91e9a 4. ./build_docker/./src/AggregateFunctions/Combinators/AggregateFunctionCombinatorsArgMinArgMax.cpp:68: DB::(anonymous namespace)::CombinatorArgMinArgMax::transformAggregateFunction(std::shared_ptr const&, DB::AggregateFunctionProperties const&, std::vector, std::allocator>> const&, DB::Array const&) const @ 0x0000000025de85ce 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 @ 0x00000000265b4737 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 @ 0x00000000265b1c12 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002839a287 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000028367bce 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028366290 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283b62c9 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002835ae03 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000028359104 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000028357f0d 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002921bdcc 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&) @ 0x000000002941f313 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&) @ 0x0000000029419aef 17. ./contrib/llvm-project/libcxx/include/vector:432: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000029421f5d 18. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000029344c1b 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*) @ 0x0000000029b3703b 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 21. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 22. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 26. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 27. asan_thread_start(void*) @ 0x000000000aa43059 28. ? @ 0x00007f35aab92ac3 29. ? @ 0x00007f35aac24850 2025.09.09 14:55:45.928654 [ 5359 ] {31866f52-8554-4fed-8e44-ecb5c8cf420a} TCPHandler: Code: 43. DB::Exception: Illegal type Dynamic of argument of aggregate function anyArgMin because the column of that type can contain values with different data types. Consider using typed subcolumns or cast column to a specific data type. (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa91e9a 4. ./build_docker/./src/AggregateFunctions/Combinators/AggregateFunctionCombinatorsArgMinArgMax.cpp:68: DB::(anonymous namespace)::CombinatorArgMinArgMax::transformAggregateFunction(std::shared_ptr const&, DB::AggregateFunctionProperties const&, std::vector, std::allocator>> const&, DB::Array const&) const @ 0x0000000025de85ce 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 @ 0x00000000265b4737 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 @ 0x00000000265b1c12 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002839a287 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000028367bce 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028366290 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283b62c9 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002835ae03 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000028359104 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000028357f0d 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002921bdcc 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&) @ 0x000000002941f313 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&) @ 0x0000000029419aef 17. ./contrib/llvm-project/libcxx/include/vector:432: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000029421f5d 18. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000029344c1b 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*) @ 0x0000000029b3703b 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 21. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 22. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 26. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 27. asan_thread_start(void*) @ 0x000000000aa43059 28. ? @ 0x00007f35aab92ac3 29. ? @ 0x00007f35aac24850 2025.09.09 14:55:45.980990 [ 4019 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 14:55:46.038752 [ 5359 ] {58ba3e9b-04da-4b35-b1ad-849e088cb049} executeQuery: Code: 36. DB::Exception: You must provide an ORDER BY or PRIMARY KEY expression in the table definition. If you don't want this table to be sorted, use ORDER BY/PRIMARY KEY (). Otherwise, you can use the setting 'create_table_empty_primary_key_by_default' to automatically add an empty primary key to the table definition. (BAD_ARGUMENTS) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:51276) (comment: 03271_dynamic_variant_in_min_max.sql) (in query: create table test (d Dynamic, index idx d type minmax);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aac868e 4. ./build_docker/./src/Storages/MergeTree/registerStorageMergeTree.cpp:658: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000002cba355c 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 @ 0x000000002b77bf53 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291b9254 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291ac835 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000291c3415 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b382fc 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 14:55:46.057855 [ 5359 ] {58ba3e9b-04da-4b35-b1ad-849e088cb049} TCPHandler: Code: 36. DB::Exception: You must provide an ORDER BY or PRIMARY KEY expression in the table definition. If you don't want this table to be sorted, use ORDER BY/PRIMARY KEY (). Otherwise, you can use the setting 'create_table_empty_primary_key_by_default' to automatically add an empty primary key to the table definition. (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aac868e 4. ./build_docker/./src/Storages/MergeTree/registerStorageMergeTree.cpp:658: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000002cba355c 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 @ 0x000000002b77bf53 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291b9254 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291ac835 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000291c3415 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b382fc 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 14:55:46.142701 [ 5359 ] {9af1006a-fed1-4919-ac03-f715c2c52439} executeQuery: Code: 43. DB::Exception: Illegal type Variant(UInt64) of argument of aggregate function max because the column of that type can contain values with different data types. Consider using typed subcolumns or cast column to a specific data type. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:51276) (comment: 03271_dynamic_variant_in_min_max.sql) (in query: select max(number::Variant(UInt64)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa91e9a 4. ./build_docker/./src/AggregateFunctions/AggregateFunctionsMinMax.cpp:40: _ZN2DBL34createAggregateFunctionSingleValueITtTyTpTnbENS_12_GLOBAL__N_123AggregateFunctionMinMaxELb1EJLb0EEEEPNS_18IAggregateFunctionERKNSt3__112basic_stringIcNS5_11char_traitsIcEENS5_9allocatorIcEEEERKNS5_6vectorINS5_10shared_ptrIKNS_9IDataTypeEEENS9_ISI_EEEERKNS_5ArrayEPKNS_8SettingsE @ 0x0000000023d9664d 5. ./build_docker/./src/AggregateFunctions/AggregateFunctionsMinMax.cpp:200: std::shared_ptr DB::(anonymous namespace)::createAggregateFunctionMinMax(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x0000000023d57629 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000265b499e 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 @ 0x00000000265b1c12 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002839a287 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000028367bce 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028366290 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283b62c9 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002835ae03 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000028359104 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000028357f0d 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002921bdcc 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&) @ 0x000000002941f313 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&) @ 0x0000000029419aef 18. ./contrib/llvm-project/libcxx/include/vector:432: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000029421f5d 19. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000029344c1b 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*) @ 0x0000000029b3703b 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 27. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 28. asan_thread_start(void*) @ 0x000000000aa43059 29. ? @ 0x00007f35aab92ac3 30. ? @ 0x00007f35aac24850 2025.09.09 14:55:46.145951 [ 5359 ] {9af1006a-fed1-4919-ac03-f715c2c52439} TCPHandler: Code: 43. DB::Exception: Illegal type Variant(UInt64) of argument of aggregate function max because the column of that type can contain values with different data types. Consider using typed subcolumns or cast column to a specific data type. (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa91e9a 4. ./build_docker/./src/AggregateFunctions/AggregateFunctionsMinMax.cpp:40: _ZN2DBL34createAggregateFunctionSingleValueITtTyTpTnbENS_12_GLOBAL__N_123AggregateFunctionMinMaxELb1EJLb0EEEEPNS_18IAggregateFunctionERKNSt3__112basic_stringIcNS5_11char_traitsIcEENS5_9allocatorIcEEEERKNS5_6vectorINS5_10shared_ptrIKNS_9IDataTypeEEENS9_ISI_EEEERKNS_5ArrayEPKNS_8SettingsE @ 0x0000000023d9664d 5. ./build_docker/./src/AggregateFunctions/AggregateFunctionsMinMax.cpp:200: std::shared_ptr DB::(anonymous namespace)::createAggregateFunctionMinMax(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x0000000023d57629 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000265b499e 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 @ 0x00000000265b1c12 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002839a287 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000028367bce 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028366290 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283b62c9 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002835ae03 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000028359104 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000028357f0d 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002921bdcc 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&) @ 0x000000002941f313 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&) @ 0x0000000029419aef 18. ./contrib/llvm-project/libcxx/include/vector:432: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000029421f5d 19. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000029344c1b 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*) @ 0x0000000029b3703b 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 27. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 28. asan_thread_start(void*) @ 0x000000000aa43059 29. ? @ 0x00007f35aab92ac3 30. ? @ 0x00007f35aac24850 2025.09.09 14:55:46.157443 [ 3013 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:55:46.169198 [ 3021 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:55:46.271222 [ 5359 ] {593a676d-e1f7-44ec-9cd7-533f245b926c} executeQuery: Code: 43. DB::Exception: Illegal type Variant(UInt64) of argument of aggregate function min because the column of that type can contain values with different data types. Consider using typed subcolumns or cast column to a specific data type. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:51276) (comment: 03271_dynamic_variant_in_min_max.sql) (in query: select min(number::Variant(UInt64)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa91e9a 4. ./build_docker/./src/AggregateFunctions/AggregateFunctionsMinMax.cpp:40: _ZN2DBL34createAggregateFunctionSingleValueITtTyTpTnbENS_12_GLOBAL__N_123AggregateFunctionMinMaxELb1EJLb1EEEEPNS_18IAggregateFunctionERKNSt3__112basic_stringIcNS5_11char_traitsIcEENS5_9allocatorIcEEEERKNS5_6vectorINS5_10shared_ptrIKNS_9IDataTypeEEENS9_ISI_EEEERKNS_5ArrayEPKNS_8SettingsE @ 0x0000000023d5da8d 5. ./build_docker/./src/AggregateFunctions/AggregateFunctionsMinMax.cpp:200: std::shared_ptr DB::(anonymous namespace)::createAggregateFunctionMinMax(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x0000000023d57369 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000265b499e 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 @ 0x00000000265b1c12 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002839a287 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000028367bce 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028366290 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283b62c9 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002835ae03 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000028359104 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000028357f0d 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002921bdcc 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&) @ 0x000000002941f313 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&) @ 0x0000000029419aef 18. ./contrib/llvm-project/libcxx/include/vector:432: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000029421f5d 19. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000029344c1b 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*) @ 0x0000000029b3703b 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 27. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 28. asan_thread_start(void*) @ 0x000000000aa43059 29. ? @ 0x00007f35aab92ac3 30. ? @ 0x00007f35aac24850 2025.09.09 14:55:46.273663 [ 5359 ] {593a676d-e1f7-44ec-9cd7-533f245b926c} TCPHandler: Code: 43. DB::Exception: Illegal type Variant(UInt64) of argument of aggregate function min because the column of that type can contain values with different data types. Consider using typed subcolumns or cast column to a specific data type. (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa91e9a 4. ./build_docker/./src/AggregateFunctions/AggregateFunctionsMinMax.cpp:40: _ZN2DBL34createAggregateFunctionSingleValueITtTyTpTnbENS_12_GLOBAL__N_123AggregateFunctionMinMaxELb1EJLb1EEEEPNS_18IAggregateFunctionERKNSt3__112basic_stringIcNS5_11char_traitsIcEENS5_9allocatorIcEEEERKNS5_6vectorINS5_10shared_ptrIKNS_9IDataTypeEEENS9_ISI_EEEERKNS_5ArrayEPKNS_8SettingsE @ 0x0000000023d5da8d 5. ./build_docker/./src/AggregateFunctions/AggregateFunctionsMinMax.cpp:200: std::shared_ptr DB::(anonymous namespace)::createAggregateFunctionMinMax(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x0000000023d57369 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000265b499e 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 @ 0x00000000265b1c12 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002839a287 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000028367bce 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028366290 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283b62c9 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002835ae03 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000028359104 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000028357f0d 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002921bdcc 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&) @ 0x000000002941f313 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&) @ 0x0000000029419aef 18. ./contrib/llvm-project/libcxx/include/vector:432: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000029421f5d 19. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000029344c1b 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*) @ 0x0000000029b3703b 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 27. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 28. asan_thread_start(void*) @ 0x000000000aa43059 29. ? @ 0x00007f35aab92ac3 30. ? @ 0x00007f35aac24850 2025.09.09 14:55:46.311180 [ 5359 ] {42101ff9-8e41-46cb-85a7-271d84c76eab} executeQuery: Code: 43. DB::Exception: Illegal type Variant(UInt64) of argument of aggregate function argMax because the column of that type can contain values with different data types. Consider using typed subcolumns or cast column to a specific data type. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:51276) (comment: 03271_dynamic_variant_in_min_max.sql) (in query: select argMax(number, number::Variant(UInt64)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa91e9a 4. ./build_docker/./src/AggregateFunctions/AggregateFunctionsArgMinArgMax.cpp:84: _ZN2DBL34createAggregateFunctionSingleValueITtTyTpTnbENS_12_GLOBAL__N_126AggregateFunctionArgMinMaxELb0EJLb0EEEEPNS_18IAggregateFunctionERKNSt3__112basic_stringIcNS5_11char_traitsIcEENS5_9allocatorIcEEEERKNS5_6vectorINS5_10shared_ptrIKNS_9IDataTypeEEENS9_ISI_EEEERKNS_5ArrayEPKNS_8SettingsE @ 0x0000000023f3ac96 5. ./build_docker/./src/AggregateFunctions/AggregateFunctionsArgMinArgMax.cpp:231: std::shared_ptr DB::(anonymous namespace)::createAggregateFunctionArgMinMax(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x0000000023ed84c9 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000265b499e 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 @ 0x00000000265b1c12 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002839a287 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000028367bce 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028366290 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283b62c9 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002835ae03 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000028359104 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000028357f0d 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002921bdcc 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&) @ 0x000000002941f313 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&) @ 0x0000000029419aef 18. ./contrib/llvm-project/libcxx/include/vector:432: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000029421f5d 19. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000029344c1b 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*) @ 0x0000000029b3703b 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 27. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 28. asan_thread_start(void*) @ 0x000000000aa43059 29. ? @ 0x00007f35aab92ac3 30. ? @ 0x00007f35aac24850 2025.09.09 14:55:46.313224 [ 5359 ] {42101ff9-8e41-46cb-85a7-271d84c76eab} TCPHandler: Code: 43. DB::Exception: Illegal type Variant(UInt64) of argument of aggregate function argMax because the column of that type can contain values with different data types. Consider using typed subcolumns or cast column to a specific data type. (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa91e9a 4. ./build_docker/./src/AggregateFunctions/AggregateFunctionsArgMinArgMax.cpp:84: _ZN2DBL34createAggregateFunctionSingleValueITtTyTpTnbENS_12_GLOBAL__N_126AggregateFunctionArgMinMaxELb0EJLb0EEEEPNS_18IAggregateFunctionERKNSt3__112basic_stringIcNS5_11char_traitsIcEENS5_9allocatorIcEEEERKNS5_6vectorINS5_10shared_ptrIKNS_9IDataTypeEEENS9_ISI_EEEERKNS_5ArrayEPKNS_8SettingsE @ 0x0000000023f3ac96 5. ./build_docker/./src/AggregateFunctions/AggregateFunctionsArgMinArgMax.cpp:231: std::shared_ptr DB::(anonymous namespace)::createAggregateFunctionArgMinMax(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x0000000023ed84c9 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000265b499e 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 @ 0x00000000265b1c12 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002839a287 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000028367bce 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028366290 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283b62c9 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002835ae03 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000028359104 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000028357f0d 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002921bdcc 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&) @ 0x000000002941f313 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&) @ 0x0000000029419aef 18. ./contrib/llvm-project/libcxx/include/vector:432: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000029421f5d 19. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000029344c1b 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*) @ 0x0000000029b3703b 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 27. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 28. asan_thread_start(void*) @ 0x000000000aa43059 29. ? @ 0x00007f35aab92ac3 30. ? @ 0x00007f35aac24850 2025.09.09 14:55:46.358592 [ 5359 ] {016ea9b6-b5c1-4b88-a444-d99cf1933d0d} executeQuery: Code: 43. DB::Exception: Illegal type Variant(UInt64) of argument of aggregate function argMin because the column of that type can contain values with different data types. Consider using typed subcolumns or cast column to a specific data type. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:51276) (comment: 03271_dynamic_variant_in_min_max.sql) (in query: select argMin(number, number::Variant(UInt64)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa91e9a 4. ./build_docker/./src/AggregateFunctions/AggregateFunctionsArgMinArgMax.cpp:84: _ZN2DBL34createAggregateFunctionSingleValueITtTyTpTnbENS_12_GLOBAL__N_126AggregateFunctionArgMinMaxELb0EJLb1EEEEPNS_18IAggregateFunctionERKNSt3__112basic_stringIcNS5_11char_traitsIcEENS5_9allocatorIcEEEERKNS5_6vectorINS5_10shared_ptrIKNS_9IDataTypeEEENS9_ISI_EEEERKNS_5ArrayEPKNS_8SettingsE @ 0x0000000023ee0776 5. ./build_docker/./src/AggregateFunctions/AggregateFunctionsArgMinArgMax.cpp:231: std::shared_ptr DB::(anonymous namespace)::createAggregateFunctionArgMinMax(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x0000000023ed8209 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000265b499e 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 @ 0x00000000265b1c12 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002839a287 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000028367bce 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028366290 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283b62c9 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002835ae03 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000028359104 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000028357f0d 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002921bdcc 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&) @ 0x000000002941f313 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&) @ 0x0000000029419aef 18. ./contrib/llvm-project/libcxx/include/vector:432: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000029421f5d 19. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000029344c1b 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*) @ 0x0000000029b3703b 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 27. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 28. asan_thread_start(void*) @ 0x000000000aa43059 29. ? @ 0x00007f35aab92ac3 30. ? @ 0x00007f35aac24850 2025.09.09 14:55:46.360563 [ 5359 ] {016ea9b6-b5c1-4b88-a444-d99cf1933d0d} TCPHandler: Code: 43. DB::Exception: Illegal type Variant(UInt64) of argument of aggregate function argMin because the column of that type can contain values with different data types. Consider using typed subcolumns or cast column to a specific data type. (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa91e9a 4. ./build_docker/./src/AggregateFunctions/AggregateFunctionsArgMinArgMax.cpp:84: _ZN2DBL34createAggregateFunctionSingleValueITtTyTpTnbENS_12_GLOBAL__N_126AggregateFunctionArgMinMaxELb0EJLb1EEEEPNS_18IAggregateFunctionERKNSt3__112basic_stringIcNS5_11char_traitsIcEENS5_9allocatorIcEEEERKNS5_6vectorINS5_10shared_ptrIKNS_9IDataTypeEEENS9_ISI_EEEERKNS_5ArrayEPKNS_8SettingsE @ 0x0000000023ee0776 5. ./build_docker/./src/AggregateFunctions/AggregateFunctionsArgMinArgMax.cpp:231: std::shared_ptr DB::(anonymous namespace)::createAggregateFunctionArgMinMax(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x0000000023ed8209 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000265b499e 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 @ 0x00000000265b1c12 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002839a287 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000028367bce 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028366290 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283b62c9 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002835ae03 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000028359104 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000028357f0d 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002921bdcc 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&) @ 0x000000002941f313 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&) @ 0x0000000029419aef 18. ./contrib/llvm-project/libcxx/include/vector:432: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000029421f5d 19. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000029344c1b 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*) @ 0x0000000029b3703b 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 27. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 28. asan_thread_start(void*) @ 0x000000000aa43059 29. ? @ 0x00007f35aab92ac3 30. ? @ 0x00007f35aac24850 2025.09.09 14:55:46.396315 [ 5359 ] {c11c1e6c-5e61-4215-97cb-e64f49c505d3} executeQuery: Code: 43. DB::Exception: Illegal type Variant(UInt64) of argument of aggregate function anyArgMax because the column of that type can contain values with different data types. Consider using typed subcolumns or cast column to a specific data type. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:51276) (comment: 03271_dynamic_variant_in_min_max.sql) (in query: select anyArgMax(number, number::Variant(UInt64)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa91e9a 4. ./build_docker/./src/AggregateFunctions/Combinators/AggregateFunctionCombinatorsArgMinArgMax.cpp:68: DB::(anonymous namespace)::CombinatorArgMinArgMax::transformAggregateFunction(std::shared_ptr const&, DB::AggregateFunctionProperties const&, std::vector, std::allocator>> const&, DB::Array const&) const @ 0x0000000025def7ee 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 @ 0x00000000265b4737 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 @ 0x00000000265b1c12 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002839a287 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000028367bce 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028366290 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283b62c9 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002835ae03 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000028359104 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000028357f0d 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002921bdcc 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&) @ 0x000000002941f313 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&) @ 0x0000000029419aef 17. ./contrib/llvm-project/libcxx/include/vector:432: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000029421f5d 18. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000029344c1b 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*) @ 0x0000000029b3703b 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 21. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 22. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 26. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 27. asan_thread_start(void*) @ 0x000000000aa43059 28. ? @ 0x00007f35aab92ac3 29. ? @ 0x00007f35aac24850 2025.09.09 14:55:46.398889 [ 5359 ] {c11c1e6c-5e61-4215-97cb-e64f49c505d3} TCPHandler: Code: 43. DB::Exception: Illegal type Variant(UInt64) of argument of aggregate function anyArgMax because the column of that type can contain values with different data types. Consider using typed subcolumns or cast column to a specific data type. (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa91e9a 4. ./build_docker/./src/AggregateFunctions/Combinators/AggregateFunctionCombinatorsArgMinArgMax.cpp:68: DB::(anonymous namespace)::CombinatorArgMinArgMax::transformAggregateFunction(std::shared_ptr const&, DB::AggregateFunctionProperties const&, std::vector, std::allocator>> const&, DB::Array const&) const @ 0x0000000025def7ee 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 @ 0x00000000265b4737 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 @ 0x00000000265b1c12 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002839a287 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000028367bce 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028366290 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283b62c9 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002835ae03 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000028359104 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000028357f0d 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002921bdcc 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&) @ 0x000000002941f313 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&) @ 0x0000000029419aef 17. ./contrib/llvm-project/libcxx/include/vector:432: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000029421f5d 18. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000029344c1b 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*) @ 0x0000000029b3703b 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 21. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 22. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 26. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 27. asan_thread_start(void*) @ 0x000000000aa43059 28. ? @ 0x00007f35aab92ac3 29. ? @ 0x00007f35aac24850 2025.09.09 14:55:46.441303 [ 5359 ] {7b6dd335-9d4d-46fd-a18d-284562c28837} executeQuery: Code: 43. DB::Exception: Illegal type Variant(UInt64) of argument of aggregate function anyArgMin because the column of that type can contain values with different data types. Consider using typed subcolumns or cast column to a specific data type. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:51276) (comment: 03271_dynamic_variant_in_min_max.sql) (in query: select anyArgMin(number, number::Variant(UInt64)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa91e9a 4. ./build_docker/./src/AggregateFunctions/Combinators/AggregateFunctionCombinatorsArgMinArgMax.cpp:68: DB::(anonymous namespace)::CombinatorArgMinArgMax::transformAggregateFunction(std::shared_ptr const&, DB::AggregateFunctionProperties const&, std::vector, std::allocator>> const&, DB::Array const&) const @ 0x0000000025de85ce 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 @ 0x00000000265b4737 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 @ 0x00000000265b1c12 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002839a287 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000028367bce 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028366290 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283b62c9 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002835ae03 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000028359104 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000028357f0d 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002921bdcc 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&) @ 0x000000002941f313 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&) @ 0x0000000029419aef 17. ./contrib/llvm-project/libcxx/include/vector:432: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000029421f5d 18. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000029344c1b 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*) @ 0x0000000029b3703b 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 21. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 22. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 26. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 27. asan_thread_start(void*) @ 0x000000000aa43059 28. ? @ 0x00007f35aab92ac3 29. ? @ 0x00007f35aac24850 2025.09.09 14:55:46.451923 [ 5359 ] {7b6dd335-9d4d-46fd-a18d-284562c28837} TCPHandler: Code: 43. DB::Exception: Illegal type Variant(UInt64) of argument of aggregate function anyArgMin because the column of that type can contain values with different data types. Consider using typed subcolumns or cast column to a specific data type. (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa91e9a 4. ./build_docker/./src/AggregateFunctions/Combinators/AggregateFunctionCombinatorsArgMinArgMax.cpp:68: DB::(anonymous namespace)::CombinatorArgMinArgMax::transformAggregateFunction(std::shared_ptr const&, DB::AggregateFunctionProperties const&, std::vector, std::allocator>> const&, DB::Array const&) const @ 0x0000000025de85ce 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 @ 0x00000000265b4737 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 @ 0x00000000265b1c12 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002839a287 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000028367bce 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028366290 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283b62c9 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002835ae03 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000028359104 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000028357f0d 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002921bdcc 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&) @ 0x000000002941f313 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&) @ 0x0000000029419aef 17. ./contrib/llvm-project/libcxx/include/vector:432: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000029421f5d 18. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000029344c1b 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*) @ 0x0000000029b3703b 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 21. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 22. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 26. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 27. asan_thread_start(void*) @ 0x000000000aa43059 28. ? @ 0x00007f35aab92ac3 29. ? @ 0x00007f35aac24850 2025.09.09 14:55:46.481642 [ 5359 ] {40914705-8481-4256-b0c1-89fa698b9d8d} executeQuery: Code: 36. DB::Exception: You must provide an ORDER BY or PRIMARY KEY expression in the table definition. If you don't want this table to be sorted, use ORDER BY/PRIMARY KEY (). Otherwise, you can use the setting 'create_table_empty_primary_key_by_default' to automatically add an empty primary key to the table definition. (BAD_ARGUMENTS) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:51276) (comment: 03271_dynamic_variant_in_min_max.sql) (in query: create table test (d Variant(UInt64), index idx d type minmax);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aac868e 4. ./build_docker/./src/Storages/MergeTree/registerStorageMergeTree.cpp:658: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000002cba355c 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 @ 0x000000002b77bf53 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291b9254 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291ac835 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000291c3415 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b382fc 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 14:55:46.483915 [ 5359 ] {40914705-8481-4256-b0c1-89fa698b9d8d} TCPHandler: Code: 36. DB::Exception: You must provide an ORDER BY or PRIMARY KEY expression in the table definition. If you don't want this table to be sorted, use ORDER BY/PRIMARY KEY (). Otherwise, you can use the setting 'create_table_empty_primary_key_by_default' to automatically add an empty primary key to the table definition. (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aac868e 4. ./build_docker/./src/Storages/MergeTree/registerStorageMergeTree.cpp:658: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000002cba355c 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 @ 0x000000002b77bf53 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291b9254 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291ac835 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000291c3415 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b382fc 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 14:55:46.962356 [ 5359 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 14:55:47.159544 [ 3033 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:55:47.171506 [ 3035 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:55:47.279237 [ 5359 ] {d126ff50-a4f7-4eb9-8717-d9b9a6bff06b} executeQuery: Code: 53. DB::Exception: Type mismatch in IN or VALUES section. Expected: UInt8. Got: Tuple. (TYPE_MISMATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:51318) (comment: 01421_assert_in_in.sql) (in query: SELECT (1, 2) IN ((1, (2, 3)), (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, DB::Field::Types::Which&&) @ 0x0000000029ac291a 4. ./build_docker/./src/Interpreters/convertFieldToType.cpp:83: DB::Field DB::(anonymous namespace)::convertNumericType(DB::Field const&, DB::IDataType const&) @ 0x0000000029aaa77e 5. ./build_docker/./src/Interpreters/convertFieldToType.cpp:0: DB::(anonymous namespace)::convertFieldToTypeImpl(DB::Field const&, DB::IDataType const&, DB::IDataType const*) @ 0x0000000029aa3fea 6. ./build_docker/./src/Interpreters/convertFieldToType.cpp:611: DB::convertFieldToType(DB::Field const&, DB::IDataType const&, DB::IDataType const*) @ 0x0000000029aa2141 7. ./src/Core/Field.h:455: DB::convertFieldToTypeStrict(DB::Field const&, DB::IDataType const&, DB::IDataType const&) @ 0x0000000029aa956b 8. ./contrib/llvm-project/libcxx/include/optional:344: DB::getSetElementsForConstantValue(std::shared_ptr const&, DB::Field const&, std::shared_ptr const&, bool) @ 0x000000002844eac7 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3398: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283990cb 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000028367bce 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028366290 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283b62c9 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002835ae03 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000028359104 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000028357f0d 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002921bdcc 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&) @ 0x000000002941f313 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&) @ 0x0000000029419aef 19. ./contrib/llvm-project/libcxx/include/vector:432: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000029421f5d 20. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000029344c1b 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*) @ 0x0000000029b3703b 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 23. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 24. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 29. asan_thread_start(void*) @ 0x000000000aa43059 30. ? @ 0x00007f35aab92ac3 31. ? @ 0x00007f35aac24850 2025.09.09 14:55:47.281683 [ 5359 ] {d126ff50-a4f7-4eb9-8717-d9b9a6bff06b} TCPHandler: Code: 53. DB::Exception: Type mismatch in IN or VALUES section. Expected: UInt8. Got: Tuple. (TYPE_MISMATCH), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, DB::Field::Types::Which&&) @ 0x0000000029ac291a 4. ./build_docker/./src/Interpreters/convertFieldToType.cpp:83: DB::Field DB::(anonymous namespace)::convertNumericType(DB::Field const&, DB::IDataType const&) @ 0x0000000029aaa77e 5. ./build_docker/./src/Interpreters/convertFieldToType.cpp:0: DB::(anonymous namespace)::convertFieldToTypeImpl(DB::Field const&, DB::IDataType const&, DB::IDataType const*) @ 0x0000000029aa3fea 6. ./build_docker/./src/Interpreters/convertFieldToType.cpp:611: DB::convertFieldToType(DB::Field const&, DB::IDataType const&, DB::IDataType const*) @ 0x0000000029aa2141 7. ./src/Core/Field.h:455: DB::convertFieldToTypeStrict(DB::Field const&, DB::IDataType const&, DB::IDataType const&) @ 0x0000000029aa956b 8. ./contrib/llvm-project/libcxx/include/optional:344: DB::getSetElementsForConstantValue(std::shared_ptr const&, DB::Field const&, std::shared_ptr const&, bool) @ 0x000000002844eac7 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3398: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283990cb 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000028367bce 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028366290 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283b62c9 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002835ae03 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000028359104 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000028357f0d 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002921bdcc 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&) @ 0x000000002941f313 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&) @ 0x0000000029419aef 19. ./contrib/llvm-project/libcxx/include/vector:432: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000029421f5d 20. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000029344c1b 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*) @ 0x0000000029b3703b 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 23. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 24. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 29. asan_thread_start(void*) @ 0x000000000aa43059 30. ? @ 0x00007f35aab92ac3 31. ? @ 0x00007f35aac24850 2025.09.09 14:55:47.933845 [ 4019 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 14:55:48.161692 [ 3059 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:55:48.173890 [ 3064 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:55:48.387254 [ 5359 ] {b22d5dfd-c5d7-4991-907b-60171f3689ab} executeQuery: Code: 47. DB::Exception: Unknown expression identifier 'x' in scope () -> x. (UNKNOWN_IDENTIFIER) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:51328) (comment: 02126_identity_user_defined_function.sql) (in query: SELECT 02126_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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String const&, String&&, String&&) @ 0x00000000283c6735 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3684: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002836a1d4 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2553: DB::QueryAnalyzer::resolveLambda(std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, DB::IdentifierResolveScope&) @ 0x00000000283ad51b 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283954e5 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000028367bce 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028366290 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283b62c9 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002835ae03 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000028359104 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000028357f0d 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002921bdcc 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&) @ 0x000000002941f313 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&) @ 0x0000000029419aef 16. ./contrib/llvm-project/libcxx/include/vector:432: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000029421f5d 17. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000029344c1b 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*) @ 0x0000000029b3703b 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 21. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 25. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 26. asan_thread_start(void*) @ 0x000000000aa43059 27. ? @ 0x00007f35aab92ac3 28. ? @ 0x00007f35aac24850 2025.09.09 14:55:48.395187 [ 5359 ] {b22d5dfd-c5d7-4991-907b-60171f3689ab} TCPHandler: Code: 47. DB::Exception: Unknown expression identifier 'x' in scope () -> x. (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String const&, String&&, String&&) @ 0x00000000283c6735 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3684: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002836a1d4 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2553: DB::QueryAnalyzer::resolveLambda(std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, DB::IdentifierResolveScope&) @ 0x00000000283ad51b 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283954e5 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000028367bce 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028366290 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283b62c9 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002835ae03 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000028359104 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000028357f0d 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002921bdcc 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&) @ 0x000000002941f313 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&) @ 0x0000000029419aef 16. ./contrib/llvm-project/libcxx/include/vector:432: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000029421f5d 17. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000029344c1b 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*) @ 0x0000000029b3703b 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 21. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 25. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 26. asan_thread_start(void*) @ 0x000000000aa43059 27. ? @ 0x00007f35aab92ac3 28. ? @ 0x00007f35aac24850 2025.09.09 14:55:48.975642 [ 5359 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 14:55:49.164088 [ 3080 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:55:49.176896 [ 3086 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:55:50.016533 [ 4023 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 14:55:50.032028 [ 5359 ] {ad9cfdbe-c2aa-4700-9e55-5db7c845605f} executeQuery: Code: 191. DB::Exception: Limit for JOIN exceeded, max rows: 1.00 thousand, current rows: 4.00 thousand: While executing FillingRightJoinSide. (SET_SIZE_LIMIT_EXCEEDED) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:51962) (comment: 01010_pmj_on_disk.sql) (in query: SELECT n, j FROM (SELECT number AS n FROM numbers(4)) nums ANY LEFT JOIN ( SELECT number * 2 AS n, number + 10 AS j FROM numbers(4000) ) js2 USING n ORDER BY n;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, String&&, String&&) @ 0x00000000278b34e0 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:24: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b3073 5. ./build_docker/./src/Interpreters/HashJoin/HashJoin.cpp:0: DB::HashJoin::addBlockToJoin(DB::Block const&, bool) @ 0x0000000029d633de 6. ./build_docker/./src/Processors/Transforms/JoiningTransform.cpp:307: DB::FillingRightJoinSideTransform::work() @ 0x000000002d9dbab1 7. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000002d34877c 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000002d34827b 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*) @ 0x000000002d36bcf7 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 14. asan_thread_start(void*) @ 0x000000000aa43059 15. ? @ 0x00007f35aab92ac3 16. ? @ 0x00007f35aac24850 2025.09.09 14:55:50.045156 [ 5359 ] {ad9cfdbe-c2aa-4700-9e55-5db7c845605f} TCPHandler: Code: 191. DB::Exception: Limit for JOIN exceeded, max rows: 1.00 thousand, current rows: 4.00 thousand: While executing FillingRightJoinSide. (SET_SIZE_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, String&&, String&&) @ 0x00000000278b34e0 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:24: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b3073 5. ./build_docker/./src/Interpreters/HashJoin/HashJoin.cpp:0: DB::HashJoin::addBlockToJoin(DB::Block const&, bool) @ 0x0000000029d633de 6. ./build_docker/./src/Processors/Transforms/JoiningTransform.cpp:307: DB::FillingRightJoinSideTransform::work() @ 0x000000002d9dbab1 7. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000002d34877c 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000002d34827b 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*) @ 0x000000002d36bcf7 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 14. asan_thread_start(void*) @ 0x000000000aa43059 15. ? @ 0x00007f35aab92ac3 16. ? @ 0x00007f35aac24850 2025.09.09 14:55:50.166811 [ 3092 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:55:50.178956 [ 3099 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:55:51.049495 [ 4023 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 14:55:51.168802 [ 3125 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:55:51.180728 [ 3127 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:55:52.077266 [ 4023 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 14:55:52.173006 [ 3146 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:55:52.183262 [ 3150 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:55:53.049540 [ 3722 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 14:55:53.175165 [ 3181 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:55:53.186107 [ 3176 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:55:54.141354 [ 4017 ] {eb9da141-b2e2-4754-b68c-6684ae6d99b6} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=1, jobs=1). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:52012) (comment: 01562_agg_null_for_empty_ahead.sql) (in query: SELECT sumMerge(s) FROM (SELECT sumMergeState(n) s FROM (SELECT sumState(number) n 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af80b71 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80746 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d34b5ca 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000002d3486e4 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000002d34827b 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002d36bcf7 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 12. asan_thread_start(void*) @ 0x000000000aa43059 13. ? @ 0x00007f35aab92ac3 14. ? @ 0x00007f35aac24850 2025.09.09 14:55:54.160855 [ 4017 ] {eb9da141-b2e2-4754-b68c-6684ae6d99b6} 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af80b71 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80746 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d34b5ca 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000002d3486e4 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000002d34827b 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002d36bcf7 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 12. asan_thread_start(void*) @ 0x000000000aa43059 13. ? @ 0x00007f35aab92ac3 14. ? @ 0x00007f35aac24850 2025.09.09 14:55:54.177303 [ 3201 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:55:54.180848 [ 4023 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 14:55:54.188060 [ 3203 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:55:55.179357 [ 3227 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:55:55.190290 [ 3218 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:55:55.244107 [ 4023 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 14:55:56.181381 [ 2734 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:55:56.192291 [ 2733 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:55:56.201145 [ 4023 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 14:55:56.489616 [ 3612 ] {} DynamicQueryHandler: Code: 452. DB::Exception: Setting max_execution_time shouldn't be greater than 60. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x0000000026f841fa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:368: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f81de0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/find_if.h:25: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f808a4 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000002d065739 10. ./build_docker/./src/Server/HTTPHandler.cpp:705: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000002d06d139 11. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000002d1cc337 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 15. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 16. asan_thread_start(void*) @ 0x000000000aa43059 17. ? @ 0x00007f35aab92ac3 18. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:55:57.182469 [ 3722 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 14:55:57.183333 [ 2764 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:55:57.194316 [ 2763 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:55:58.185282 [ 2780 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:55:58.196523 [ 2776 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:55:58.203370 [ 4017 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 14:55:59.038529 [ 4023 ] {a872e855-beb3-479b-8f73-2b84d0e2e380} executeQuery: Code: 107. DB::ErrnoException: Cannot open file /var/lib/clickhouse/user_files/a: , errno: 2, strerror: No such file or directory: while executing 'FUNCTION file(materialize('a'_String) :: 2) -> file(materialize('a'_String)) String : 1'. (FILE_DOESNT_EXIST) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:52080) (comment: 02843_context_has_expired.sql) (in query: SELECT 1 in (SELECT file(materialize('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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::ErrnoException::ErrnoException(int, int, FormatStringHelperImpl::type>, String&) @ 0x000000001ae9f052 4. ./src/Common/Exception.h:237: void DB::ErrnoException::throwFromPath(int, String const&, FormatStringHelperImpl::type>, String&) @ 0x000000001ae9e96f 5. ./build_docker/./src/IO/ReadBufferFromFile.cpp:48: DB::ReadBufferFromFile::ReadBufferFromFile(String const&, unsigned long, int, char*, unsigned long, std::optional, std::shared_ptr) @ 0x000000001aea766d 6. DB::FunctionFile::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aad15d0 7. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aac9135 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000cccce5b 9. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccce65c 10. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd2030 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x00000000286fc2bd 12. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000002d9c29ae 13. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 14. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 15. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:381: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000002d34bd35 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7eaf0 19. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001af8a79f 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 22. asan_thread_start(void*) @ 0x000000000aa43059 23. ? @ 0x00007f35aab92ac3 24. ? @ 0x00007f35aac24850 2025.09.09 14:55:59.042921 [ 4023 ] {a872e855-beb3-479b-8f73-2b84d0e2e380} TCPHandler: Code: 107. DB::ErrnoException: Cannot open file /var/lib/clickhouse/user_files/a: , errno: 2, strerror: No such file or directory: while executing 'FUNCTION file(materialize('a'_String) :: 2) -> file(materialize('a'_String)) String : 1'. (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::ErrnoException::ErrnoException(int, int, FormatStringHelperImpl::type>, String&) @ 0x000000001ae9f052 4. ./src/Common/Exception.h:237: void DB::ErrnoException::throwFromPath(int, String const&, FormatStringHelperImpl::type>, String&) @ 0x000000001ae9e96f 5. ./build_docker/./src/IO/ReadBufferFromFile.cpp:48: DB::ReadBufferFromFile::ReadBufferFromFile(String const&, unsigned long, int, char*, unsigned long, std::optional, std::shared_ptr) @ 0x000000001aea766d 6. DB::FunctionFile::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aad15d0 7. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aac9135 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000cccce5b 9. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccce65c 10. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd2030 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x00000000286fc2bd 12. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000002d9c29ae 13. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 14. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 15. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:381: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000002d34bd35 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7eaf0 19. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001af8a79f 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 22. asan_thread_start(void*) @ 0x000000000aa43059 23. ? @ 0x00007f35aab92ac3 24. ? @ 0x00007f35aac24850 2025.09.09 14:55:59.152248 [ 3722 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 14:55:59.187526 [ 2806 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:55:59.252356 [ 2803 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:55:59.536572 [ 4023 ] {b7d55c54-5cc4-4aed-9726-fadca99c0c4e} executeQuery: Code: 62. DB::Exception: Cannot TRUNCATE dictionary. (SYNTAX_ERROR) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:52080) (comment: 02843_context_has_expired.sql) (in query: DROP DICTIONARY 02843_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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aac868e 4. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:262: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x00000000291f1adc 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x00000000291ed665 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x00000000291ebd68 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x00000000291eb7ed 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b382fc 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 11. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 15. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 16. asan_thread_start(void*) @ 0x000000000aa43059 17. ? @ 0x00007f35aab92ac3 18. ? @ 0x00007f35aac24850 2025.09.09 14:55:59.539868 [ 4023 ] {b7d55c54-5cc4-4aed-9726-fadca99c0c4e} 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aac868e 4. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:262: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x00000000291f1adc 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x00000000291ed665 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x00000000291ebd68 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x00000000291eb7ed 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b382fc 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 11. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 15. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 16. asan_thread_start(void*) @ 0x000000000aa43059 17. ? @ 0x00007f35aab92ac3 18. ? @ 0x00007f35aac24850 2025.09.09 14:56:00.195956 [ 4017 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 14:56:00.212893 [ 2825 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:56:00.254339 [ 2831 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:56:01.194078 [ 3722 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 14:56:01.214726 [ 2855 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:56:01.256333 [ 2858 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:56:02.198284 [ 4023 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 14:56:02.217715 [ 2886 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:56:02.258449 [ 2888 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:56:03.204832 [ 3722 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 14:56:03.220224 [ 2912 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:56:03.260630 [ 2905 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:56:04.218750 [ 3722 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 14:56:04.225139 [ 2934 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:56:04.262930 [ 2937 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:56:05.163955 [ 4022 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 14:56:05.230911 [ 2949 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:56:05.264866 [ 2957 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:56:05.810402 [ 3722 ] {ec9b44d1-d83b-4a76-87ad-b335ca0a8cd9} executeQuery: Code: 33. DB::Exception: Error while parsing Nullable: got an unquoted string n instead of a number: (at row 1) : Could not print diagnostic info because two last rows aren't in buffer (rare case) : (in file/uri /var/lib/clickhouse/user_files/test_1.data): While executing CustomSeparatedRowInputFormat: While executing File. (CANNOT_READ_ALL_DATA) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:33184) (comment: 02130_parse_quoted_null.sh) (in query: select * from file('test_1.data', 'CustomSeparated', 'x Nullable(Float64), y Nullable(UInt64)') settings input_format_parallel_parsing=0, format_custom_escaping_rule='Quoted'), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000aad4b34 4. ./build_docker/./src/DataTypes/Serializations/SerializationNullable.cpp:543: void DB::deserializeTextQuotedImpl(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, std::shared_ptr const&, bool&)::'lambda0'(DB::IColumn&, DB::ReadBuffer&)::operator()(DB::IColumn&, DB::ReadBuffer&) const @ 0x0000000027b8ac80 5. ./build_docker/./src/DataTypes/Serializations/SerializationNullable.cpp:550: void DB::deserializeTextQuotedImpl(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, std::shared_ptr const&, bool&) @ 0x0000000027b81bc2 6. ./build_docker/./src/DataTypes/Serializations/SerializationNullable.cpp:558: DB::SerializationNullable::deserializeTextQuoted(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x0000000027b7d331 7. ./build_docker/./src/Formats/EscapingRuleUtils.cpp:0: DB::deserializeFieldByEscapingRule(std::shared_ptr const&, std::shared_ptr const&, DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings::EscapingRule, DB::FormatSettings const&) @ 0x000000002d1e4ed4 8. ./build_docker/./src/Processors/Formats/RowInputFormatWithNamesAndTypes.cpp:252: DB::RowInputFormatWithNamesAndTypes::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x000000002d4ba246 9. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:0: DB::IRowInputFormat::read() @ 0x000000002d46d965 10. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000002d37a746 11. ./src/Processors/Chunk.h:110: DB::ISource::tryGenerate() @ 0x000000002d329c18 12. ./build_docker/./src/Processors/ISource.cpp:0: DB::ISource::work() @ 0x000000002d3290a1 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 16. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 17. ./build_docker/./src/Storages/StorageFile.cpp:1454: DB::StorageFileSource::generate() @ 0x000000002b7988be 18. ./src/Processors/Chunk.h:110: DB::ISource::tryGenerate() @ 0x000000002d329c18 19. ./build_docker/./src/Processors/ISource.cpp:0: DB::ISource::work() @ 0x000000002d3290a1 20. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:381: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000002d34bd35 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7eaf0 24. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001af8a79f 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 27. asan_thread_start(void*) @ 0x000000000aa43059 28. ? @ 0x00007f35aab92ac3 29. ? @ 0x00007f35aac24850 2025.09.09 14:56:05.818033 [ 3722 ] {ec9b44d1-d83b-4a76-87ad-b335ca0a8cd9} TCPHandler: Code: 33. DB::Exception: Error while parsing Nullable: got an unquoted string n instead of a number: (at row 1) : Could not print diagnostic info because two last rows aren't in buffer (rare case) : (in file/uri /var/lib/clickhouse/user_files/test_1.data): While executing CustomSeparatedRowInputFormat: While executing File. (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000aad4b34 4. ./build_docker/./src/DataTypes/Serializations/SerializationNullable.cpp:543: void DB::deserializeTextQuotedImpl(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, std::shared_ptr const&, bool&)::'lambda0'(DB::IColumn&, DB::ReadBuffer&)::operator()(DB::IColumn&, DB::ReadBuffer&) const @ 0x0000000027b8ac80 5. ./build_docker/./src/DataTypes/Serializations/SerializationNullable.cpp:550: void DB::deserializeTextQuotedImpl(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, std::shared_ptr const&, bool&) @ 0x0000000027b81bc2 6. ./build_docker/./src/DataTypes/Serializations/SerializationNullable.cpp:558: DB::SerializationNullable::deserializeTextQuoted(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x0000000027b7d331 7. ./build_docker/./src/Formats/EscapingRuleUtils.cpp:0: DB::deserializeFieldByEscapingRule(std::shared_ptr const&, std::shared_ptr const&, DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings::EscapingRule, DB::FormatSettings const&) @ 0x000000002d1e4ed4 8. ./build_docker/./src/Processors/Formats/RowInputFormatWithNamesAndTypes.cpp:252: DB::RowInputFormatWithNamesAndTypes::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x000000002d4ba246 9. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:0: DB::IRowInputFormat::read() @ 0x000000002d46d965 10. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000002d37a746 11. ./src/Processors/Chunk.h:110: DB::ISource::tryGenerate() @ 0x000000002d329c18 12. ./build_docker/./src/Processors/ISource.cpp:0: DB::ISource::work() @ 0x000000002d3290a1 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 16. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 17. ./build_docker/./src/Storages/StorageFile.cpp:1454: DB::StorageFileSource::generate() @ 0x000000002b7988be 18. ./src/Processors/Chunk.h:110: DB::ISource::tryGenerate() @ 0x000000002d329c18 19. ./build_docker/./src/Processors/ISource.cpp:0: DB::ISource::work() @ 0x000000002d3290a1 20. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:381: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000002d34bd35 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7eaf0 24. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001af8a79f 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 27. asan_thread_start(void*) @ 0x000000000aa43059 28. ? @ 0x00007f35aab92ac3 29. ? @ 0x00007f35aac24850 2025.09.09 14:56:06.198765 [ 3722 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 14:56:06.233195 [ 2975 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:56:06.268004 [ 2970 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:56:07.201135 [ 3722 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 14:56:07.235308 [ 2993 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:56:07.270048 [ 2995 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:56:08.047390 [ 3651 ] {52dcb4d4-84c8-440f-ae37-1cbacc272e52} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=773, jobs=736). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:40092) (comment: 01603_decimal_mult_float.sql) (in query: SELECT round(sum(`__table1`.`f64` * _CAST('0.1', 'Decimal(18, 2)')), 6) AS `round(sum(multiply(f64, toDecimal64(0.1, 2))), 6)` FROM `test_3`.`test01603` AS `__table1`), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af872f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af7b2d1 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af7c3f3 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d36920d 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000002d369e5f 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processOrdinaryQuery() @ 0x000000002d18af7b 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d17644a 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 15. asan_thread_start(void*) @ 0x000000000aa43059 16. ? @ 0x00007f35aab92ac3 17. ? @ 0x00007f35aac24850 2025.09.09 14:56:08.055161 [ 3651 ] {52dcb4d4-84c8-440f-ae37-1cbacc272e52} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=773, jobs=736). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af872f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af7b2d1 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af7c3f3 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d36920d 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000002d369e5f 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processOrdinaryQuery() @ 0x000000002d18af7b 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d17644a 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 15. asan_thread_start(void*) @ 0x000000000aa43059 16. ? @ 0x00007f35aab92ac3 17. ? @ 0x00007f35aac24850 2025.09.09 14:56:08.073194 [ 4017 ] {b058fb53-2e3f-4242-9965-ee661c0da1ad} executeQuery: Code: 439. DB::Exception: Received from 127.0.0.4:9000. DB::Exception: Cannot schedule a task: fault injected (threads=773, jobs=736). Stack trace: 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af872f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af7b2d1 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af7c3f3 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d36920d 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000002d369e5f 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processOrdinaryQuery() @ 0x000000002d18af7b 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d17644a 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 15. asan_thread_start(void*) @ 0x000000000aa43059 16. ? @ 0x00007f35aab92ac3 17. ? @ 0x00007f35aac24850 : While executing Remote. (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:33066) (comment: 01603_decimal_mult_float.sql) (in query: SELECT round(sum(f64 * toDecimal64(0.1, 2)), 6) FROM test01603;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. ./contrib/llvm-project/libcxx/include/string:1499: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x000000001aeb974e 3. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::Connection::receiveException() const @ 0x000000002cee6c6a 4. ./build_docker/./src/Client/Connection.cpp:0: DB::Connection::receivePacket() @ 0x000000002cef780e 5. ./build_docker/./src/Client/MultiplexedConnections.cpp:340: DB::MultiplexedConnections::receivePacketUnlocked(std::function) @ 0x000000002cf8e09e 6. ./build_docker/./src/QueryPipeline/RemoteQueryExecutorReadContext.cpp:0: DB::RemoteQueryExecutorReadContext::Task::run(std::function, std::function) @ 0x00000000278ad616 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000278ab436 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000278aaa44 9. ./contrib/boost/boost/context/fiber_ucontext.hpp:82: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x00000000278a8394 2025.09.09 14:56:08.079795 [ 4017 ] {b058fb53-2e3f-4242-9965-ee661c0da1ad} TCPHandler: Code: 439. DB::Exception: Received from 127.0.0.4:9000. DB::Exception: Cannot schedule a task: fault injected (threads=773, jobs=736). Stack trace: 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af872f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af7b2d1 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af7c3f3 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d36920d 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000002d369e5f 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processOrdinaryQuery() @ 0x000000002d18af7b 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d17644a 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 15. asan_thread_start(void*) @ 0x000000000aa43059 16. ? @ 0x00007f35aab92ac3 17. ? @ 0x00007f35aac24850 : 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. ./contrib/llvm-project/libcxx/include/string:1499: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x000000001aeb974e 3. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::Connection::receiveException() const @ 0x000000002cee6c6a 4. ./build_docker/./src/Client/Connection.cpp:0: DB::Connection::receivePacket() @ 0x000000002cef780e 5. ./build_docker/./src/Client/MultiplexedConnections.cpp:340: DB::MultiplexedConnections::receivePacketUnlocked(std::function) @ 0x000000002cf8e09e 6. ./build_docker/./src/QueryPipeline/RemoteQueryExecutorReadContext.cpp:0: DB::RemoteQueryExecutorReadContext::Task::run(std::function, std::function) @ 0x00000000278ad616 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000278ab436 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000278aaa44 9. ./contrib/boost/boost/context/fiber_ucontext.hpp:82: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x00000000278a8394 2025.09.09 14:56:08.091332 [ 4018 ] {07780179-4c7e-49c9-aec7-4330ba25daa3} executeQuery: Code: 210. DB::NetException: Connection reset by peer, while writing to socket ([::ffff:127.0.0.2]:9000 -> [::ffff:127.0.0.1]:57844). (NETWORK_ERROR) (version 24.8.14.10505.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:57844) (comment: 01603_decimal_mult_float.sql) (in query: SELECT round(sum(`__table1`.`f64` * _CAST('0.1', 'Decimal(18, 2)')), 6) AS `round(sum(multiply(f64, toDecimal64(0.1, 2))), 6)` FROM `test_3`.`test01603` AS `__table1`), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 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&&) @ 0x000000001b0b7a5f 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:158: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000001b0bab02 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:201: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000002cf09bf7 5. ./src/IO/WriteBuffer.h:66: DB::TCPHandler::sendData(DB::Block const&) @ 0x000000002d190f6b 6. ./contrib/llvm-project/libcxx/include/__hash_table:1473: DB::TCPHandler::processOrdinaryQuery() @ 0x000000002d18b989 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d17644a 8. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 12. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 13. asan_thread_start(void*) @ 0x000000000aa43059 14. ? @ 0x00007f35aab92ac3 15. ? @ 0x00007f35aac24850 2025.09.09 14:56:08.111888 [ 3766 ] {d65f3882-2805-4698-b38e-d0d9d22b7fc6} executeQuery: Code: 210. DB::NetException: Connection reset by peer, while writing to socket ([::ffff:127.0.0.6]:9000 -> [::ffff:127.0.0.1]:42182). (NETWORK_ERROR) (version 24.8.14.10505.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:42182) (comment: 01603_decimal_mult_float.sql) (in query: SELECT round(sum(`__table1`.`f64` * _CAST('0.1', 'Decimal(18, 2)')), 6) AS `round(sum(multiply(f64, toDecimal64(0.1, 2))), 6)` FROM `test_3`.`test01603` AS `__table1`), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 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&&) @ 0x000000001b0b7a5f 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:158: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000001b0bab02 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:201: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000002cf09bf7 5. ./src/IO/WriteBuffer.h:66: DB::TCPHandler::sendData(DB::Block const&) @ 0x000000002d190f6b 6. ./contrib/llvm-project/libcxx/include/__hash_table:1473: DB::TCPHandler::processOrdinaryQuery() @ 0x000000002d18b989 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d17644a 8. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 12. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 13. asan_thread_start(void*) @ 0x000000000aa43059 14. ? @ 0x00007f35aab92ac3 15. ? @ 0x00007f35aac24850 2025.09.09 14:56:08.113460 [ 4018 ] {07780179-4c7e-49c9-aec7-4330ba25daa3} TCPHandler: Can't send logs to client: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::ffff:127.0.0.2]:9000 -> [::ffff:127.0.0.1]:57844). (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 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&&) @ 0x000000001b0b7a5f 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:169: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000001b0bada2 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:201: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000002cf09bf7 5. ./src/IO/WriteBuffer.h:66: DB::TCPHandler::sendLogData(DB::Block const&) @ 0x000000002d1a9beb 6. ./contrib/llvm-project/libcxx/include/__hash_table:1473: DB::TCPHandler::sendLogs() @ 0x000000002d18db59 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d176902 8. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 12. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 13. asan_thread_start(void*) @ 0x000000000aa43059 14. ? @ 0x00007f35aab92ac3 15. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:56:08.120813 [ 4018 ] {07780179-4c7e-49c9-aec7-4330ba25daa3} TCPHandler: Code: 210. DB::NetException: Connection reset by peer, while writing to socket ([::ffff:127.0.0.2]:9000 -> [::ffff:127.0.0.1]:57844). (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 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&&) @ 0x000000001b0b7a5f 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:158: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000001b0bab02 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:201: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000002cf09bf7 5. ./src/IO/WriteBuffer.h:66: DB::TCPHandler::sendData(DB::Block const&) @ 0x000000002d190f6b 6. ./contrib/llvm-project/libcxx/include/__hash_table:1473: DB::TCPHandler::processOrdinaryQuery() @ 0x000000002d18b989 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d17644a 8. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 12. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 13. asan_thread_start(void*) @ 0x000000000aa43059 14. ? @ 0x00007f35aab92ac3 15. ? @ 0x00007f35aac24850 2025.09.09 14:56:08.127226 [ 4018 ] {07780179-4c7e-49c9-aec7-4330ba25daa3} TCPHandler: Client has gone away. 2025.09.09 14:56:08.134377 [ 3766 ] {d65f3882-2805-4698-b38e-d0d9d22b7fc6} TCPHandler: Can't send logs to client: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::ffff:127.0.0.6]:9000 -> [::ffff:127.0.0.1]:42182). (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 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&&) @ 0x000000001b0b7a5f 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:169: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000001b0bada2 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:201: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000002cf09bf7 5. ./src/IO/WriteBuffer.h:66: DB::TCPHandler::sendLogData(DB::Block const&) @ 0x000000002d1a9beb 6. ./contrib/llvm-project/libcxx/include/__hash_table:1473: DB::TCPHandler::sendLogs() @ 0x000000002d18db59 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d176902 8. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 12. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 13. asan_thread_start(void*) @ 0x000000000aa43059 14. ? @ 0x00007f35aab92ac3 15. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:56:08.147607 [ 3766 ] {d65f3882-2805-4698-b38e-d0d9d22b7fc6} TCPHandler: Code: 210. DB::NetException: Connection reset by peer, while writing to socket ([::ffff:127.0.0.6]:9000 -> [::ffff:127.0.0.1]:42182). (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 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&&) @ 0x000000001b0b7a5f 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:158: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000001b0bab02 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:201: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000002cf09bf7 5. ./src/IO/WriteBuffer.h:66: DB::TCPHandler::sendData(DB::Block const&) @ 0x000000002d190f6b 6. ./contrib/llvm-project/libcxx/include/__hash_table:1473: DB::TCPHandler::processOrdinaryQuery() @ 0x000000002d18b989 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d17644a 8. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 12. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 13. asan_thread_start(void*) @ 0x000000000aa43059 14. ? @ 0x00007f35aab92ac3 15. ? @ 0x00007f35aac24850 2025.09.09 14:56:08.156184 [ 3766 ] {d65f3882-2805-4698-b38e-d0d9d22b7fc6} TCPHandler: Client has gone away. 2025.09.09 14:56:08.222729 [ 3722 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 14:56:08.237145 [ 3026 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:56:08.271966 [ 3015 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:56:09.202434 [ 3722 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 14:56:09.239286 [ 3035 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:56:09.274265 [ 3038 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:56:10.212221 [ 4022 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 14:56:10.241598 [ 3052 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:56:10.276419 [ 3055 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:56:10.945810 [ 4022 ] {35d08d91-9226-4a03-a7b7-c602b8337c80} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=0, jobs=0). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:54472) (comment: 01109_sc0rp10_string_hash_map_zero_bytes.sql) (in query: -- Test that the string hash map works properly with keys containing zero -- bytes. -- Keys with no central '1' are mostly duplicates. The unique keys -- in this group are '', '\0', ...., '\0 x 34', to a total of 35. All other -- keys are unique. select count(*) = 18 * 18 * 17 + 35 from ( select key from ( with 18 as n select repeat('\0', number % n) || repeat('1', intDiv(number, n) % n) || repeat('\0', intDiv(number, n * n) % n) key from numbers(18 * 18 * 18)) group 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af80b71 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80746 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d34b5ca 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000002d3486e4 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000002d34827b 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002d36bcf7 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 12. asan_thread_start(void*) @ 0x000000000aa43059 13. ? @ 0x00007f35aab92ac3 14. ? @ 0x00007f35aac24850 2025.09.09 14:56:10.969540 [ 4022 ] {35d08d91-9226-4a03-a7b7-c602b8337c80} 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af80b71 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80746 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d34b5ca 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000002d3486e4 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000002d34827b 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002d36bcf7 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 12. asan_thread_start(void*) @ 0x000000000aa43059 13. ? @ 0x00007f35aab92ac3 14. ? @ 0x00007f35aac24850 2025.09.09 14:56:11.243839 [ 3074 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:56:11.261364 [ 4022 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 14:56:11.278521 [ 3086 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:56:11.986686 [ 4022 ] {0cbc12aa-7f6b-4695-8734-01508e08eea5} executeQuery: Code: 36. DB::Exception: Columns: a listed both in columns to sum and in partition key. That is not allowed. (BAD_ARGUMENTS) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:54492) (comment: 01373_summing_merge_tree_explicit_columns_definition.sql) (in query: CREATE TABLE tt_error_1373 (`a` Int64, `d` Int64, `val` Int64) ENGINE = SummingMergeTree((a, val)) PARTITION BY a ORDER BY d SETTINGS index_granularity = 61920, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 0., replace_long_file_name_to_hash = false, max_file_name_length = 61, min_bytes_for_full_part_storage = 536870912, compact_parts_max_bytes_to_buffer = 201930469, compact_parts_max_granules_to_buffer = 47, compact_parts_merge_max_bytes_to_prefetch_part = 16554574, merge_max_block_size = 10841, old_parts_lifetime = 364., prefer_fetch_merged_part_size_threshold = 1904792582, 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 = 29810732, concurrent_part_removal_threshold = 0, allow_vertical_merges_from_compact_to_wide_parts = true, cache_populated_by_fetch = true, marks_compress_block_size = 22997, primary_key_compress_block_size = 62342), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000aad4b34 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:1079: DB::MergeTreeData::MergingParams::check(DB::StorageInMemoryMetadata const&) const @ 0x000000002c436cf6 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:405: DB::MergeTreeData::MergeTreeData(DB::StorageID const&, DB::StorageInMemoryMetadata const&, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>, bool, DB::LoadingStrictnessLevel, std::function) @ 0x000000002c432933 6. ./build_docker/./src/Storages/StorageMergeTree.cpp:96: DB::StorageMergeTree::StorageMergeTree(DB::StorageID const&, String const&, DB::StorageInMemoryMetadata const&, DB::LoadingStrictnessLevel, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>) @ 0x000000002cbacb89 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:1460: std::shared_ptr std::allocate_shared[abi:v15007], DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, void>(std::allocator const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&) @ 0x000000002cbabafa 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:962: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000002cba21b8 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 @ 0x000000002b77bf53 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291b9254 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291ac835 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000291c3415 13. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b382fc 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 16. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 20. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 21. asan_thread_start(void*) @ 0x000000000aa43059 22. ? @ 0x00007f35aab92ac3 23. ? @ 0x00007f35aac24850 2025.09.09 14:56:11.989459 [ 4022 ] {0cbc12aa-7f6b-4695-8734-01508e08eea5} TCPHandler: Code: 36. DB::Exception: Columns: a listed both in columns to sum and in partition key. That is not allowed. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000aad4b34 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:1079: DB::MergeTreeData::MergingParams::check(DB::StorageInMemoryMetadata const&) const @ 0x000000002c436cf6 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:405: DB::MergeTreeData::MergeTreeData(DB::StorageID const&, DB::StorageInMemoryMetadata const&, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>, bool, DB::LoadingStrictnessLevel, std::function) @ 0x000000002c432933 6. ./build_docker/./src/Storages/StorageMergeTree.cpp:96: DB::StorageMergeTree::StorageMergeTree(DB::StorageID const&, String const&, DB::StorageInMemoryMetadata const&, DB::LoadingStrictnessLevel, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>) @ 0x000000002cbacb89 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:1460: std::shared_ptr std::allocate_shared[abi:v15007], DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, void>(std::allocator const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&) @ 0x000000002cbabafa 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:962: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000002cba21b8 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 @ 0x000000002b77bf53 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291b9254 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291ac835 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000291c3415 13. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b382fc 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 16. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 20. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 21. asan_thread_start(void*) @ 0x000000000aa43059 22. ? @ 0x00007f35aab92ac3 23. ? @ 0x00007f35aac24850 2025.09.09 14:56:12.310256 [ 3105 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:56:12.311938 [ 3106 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:56:12.312663 [ 4022 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 14:56:13.312201 [ 3122 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:56:13.314145 [ 3125 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:56:13.376238 [ 5359 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 14:56:14.314215 [ 3158 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:56:14.316184 [ 3158 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:56:14.410666 [ 5359 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 14:56:15.316740 [ 3196 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:56:15.321434 [ 3198 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:56:15.367840 [ 5359 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 14:56:15.882940 [ 4022 ] {dc7e44a6-0f80-4ed2-ba92-9a8fd4d3f285} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=13, jobs=3): (while reading column json): (while reading from part /var/lib/clickhouse/store/16e/16e3554b-9cb1-4d7c-b784-c55abb7214c7/all_7_7_0/ in table test_3.test (16e3554b-9cb1-4d7c-b784-c55abb7214c7) located on disk default of type local, from mark 0 with max_rows_to_read = 5): While executing MergeTreeSelect(pool: ReadPoolParallelReplicas, algorithm: Thread). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:54530) (comment: 03207_json_read_subcolumns_1_wide_merge_tree.gen.sql) (in query: select distinct arrayJoin(JSONAllPathsWithTypes(json)) as paths_with_types from test order by paths_with_types;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af80b71 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80746 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002c765aab 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:1197: ? @ 0x000000002c7602b8 8. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x000000002c75fc2b 9. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:0: DB::MergeTreeReaderWide::addStream(DB::ISerialization::SubstreamPath const&, String const&) @ 0x000000002c802c31 10. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:312: 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>>>&) @ 0x000000002c803f22 11. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:365: 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&) @ 0x000000002c8051f4 12. ./src/DataTypes/Serializations/ISerialization.h:225: DB::SerializationArray::enumerateStreams(DB::ISerialization::EnumerateStreamsSettings&, std::function const&, DB::ISerialization::SubstreamData const&) const @ 0x0000000027ab5907 13. ./build_docker/./src/DataTypes/Serializations/SerializationVariant.cpp:0: DB::SerializationVariant::enumerateStreams(DB::ISerialization::EnumerateStreamsSettings&, std::function const&, DB::ISerialization::SubstreamData const&) const @ 0x0000000027c45dd6 14. ./build_docker/./src/DataTypes/Serializations/SerializationDynamic.cpp:0: DB::SerializationDynamic::enumerateStreams(DB::ISerialization::EnumerateStreamsSettings&, std::function const&, DB::ISerialization::SubstreamData const&) const @ 0x0000000027aecf27 15. ./build_docker/./src/DataTypes/Serializations/SerializationObject.cpp:0: DB::SerializationObject::enumerateStreams(DB::ISerialization::EnumerateStreamsSettings&, std::function const&, DB::ISerialization::SubstreamData const&) const @ 0x0000000027bb7c20 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002c8001b5 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:109: DB::MergeTreeReaderWide::prefetchForAllColumns(Priority, unsigned long, unsigned long, unsigned long, bool) @ 0x000000002c7ff7eb 18. ./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>>&) @ 0x000000002c80099a 19. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:118: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7c9d8a 20. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x000000002c7e0473 21. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x000000002c7dbec3 22. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:0: DB::MergeTreeReadTask::read(DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002c82d05b 23. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:38: DB::MergeTreeThreadSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&, DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002de66094 24. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:0: DB::MergeTreeSelectProcessor::read() @ 0x000000002c8242f9 25. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000002de6d77a 26. ./build_docker/./src/Processors/ISource.cpp:0: DB::ISource::work() @ 0x000000002d3290a1 27. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 28. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 29. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000002d34877c 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000002d34827b 31. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002d36bcf7 2025.09.09 14:56:15.905253 [ 4022 ] {dc7e44a6-0f80-4ed2-ba92-9a8fd4d3f285} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=13, jobs=3): (while reading column json): (while reading from part /var/lib/clickhouse/store/16e/16e3554b-9cb1-4d7c-b784-c55abb7214c7/all_7_7_0/ in table test_3.test (16e3554b-9cb1-4d7c-b784-c55abb7214c7) located on disk default of type local, from mark 0 with max_rows_to_read = 5): While executing MergeTreeSelect(pool: ReadPoolParallelReplicas, algorithm: Thread). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af80b71 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80746 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002c765aab 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:1197: ? @ 0x000000002c7602b8 8. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x000000002c75fc2b 9. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:0: DB::MergeTreeReaderWide::addStream(DB::ISerialization::SubstreamPath const&, String const&) @ 0x000000002c802c31 10. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:312: 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>>>&) @ 0x000000002c803f22 11. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:365: 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&) @ 0x000000002c8051f4 12. ./src/DataTypes/Serializations/ISerialization.h:225: DB::SerializationArray::enumerateStreams(DB::ISerialization::EnumerateStreamsSettings&, std::function const&, DB::ISerialization::SubstreamData const&) const @ 0x0000000027ab5907 13. ./build_docker/./src/DataTypes/Serializations/SerializationVariant.cpp:0: DB::SerializationVariant::enumerateStreams(DB::ISerialization::EnumerateStreamsSettings&, std::function const&, DB::ISerialization::SubstreamData const&) const @ 0x0000000027c45dd6 14. ./build_docker/./src/DataTypes/Serializations/SerializationDynamic.cpp:0: DB::SerializationDynamic::enumerateStreams(DB::ISerialization::EnumerateStreamsSettings&, std::function const&, DB::ISerialization::SubstreamData const&) const @ 0x0000000027aecf27 15. ./build_docker/./src/DataTypes/Serializations/SerializationObject.cpp:0: DB::SerializationObject::enumerateStreams(DB::ISerialization::EnumerateStreamsSettings&, std::function const&, DB::ISerialization::SubstreamData const&) const @ 0x0000000027bb7c20 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002c8001b5 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:109: DB::MergeTreeReaderWide::prefetchForAllColumns(Priority, unsigned long, unsigned long, unsigned long, bool) @ 0x000000002c7ff7eb 18. ./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>>&) @ 0x000000002c80099a 19. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:118: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7c9d8a 20. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x000000002c7e0473 21. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x000000002c7dbec3 22. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:0: DB::MergeTreeReadTask::read(DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002c82d05b 23. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:38: DB::MergeTreeThreadSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&, DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002de66094 24. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:0: DB::MergeTreeSelectProcessor::read() @ 0x000000002c8242f9 25. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000002de6d77a 26. ./build_docker/./src/Processors/ISource.cpp:0: DB::ISource::work() @ 0x000000002d3290a1 27. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 28. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 29. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000002d34877c 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000002d34827b 31. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002d36bcf7 2025.09.09 14:56:16.319157 [ 3220 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:56:16.323758 [ 3219 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:56:16.482809 [ 4022 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 14:56:16.579449 [ 3722 ] {5d17ca9e-a617-4763-95f5-096040654ea5} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=9, jobs=0): (while reading column query_id): (while reading from part /var/lib/clickhouse/store/969/96984bc5-93f4-461f-9504-9500ec594f44/202509_1_1_0/ in table system.filesystem_cache_log (96984bc5-93f4-461f-9504-9500ec594f44) located on disk default of type local, from mark 0 with max_rows_to_read = 83): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:54588) (comment: 02503_cache_on_write_with_small_segment_size.sh) (in query: select count() from system.filesystem_cache_log where query_id = 'sQXAtqXV' AND read_type == 'READ_FROM_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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af80b71 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80746 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000266005a2 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000265fffb4 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:1197: ? @ 0x00000000265fd4e7 9. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:62: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x00000000265e6fbd 10. ./contrib/llvm-project/libcxx/include/future:1123: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x00000000265e7bb3 11. DB::ReadBuffer::next() @ 0x000000000b528aeb 12. ./src/IO/ReadBuffer.h:0: DB::CompressedReadBufferBase::readCompressedData(unsigned long&, unsigned long&, bool) @ 0x000000002775f11b 13. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:22: DB::CompressedReadBufferFromFile::nextImpl() @ 0x0000000027763d41 14. DB::ReadBuffer::next() @ 0x000000000b528aeb 15. ./build_docker/./src/DataTypes/Serializations/SerializationString.cpp:159: void DB::deserializeBinarySSE2<1>(DB::PODArray, 63ul, 64ul>&, DB::PODArray, 63ul, 64ul>&, DB::ReadBuffer&, unsigned long) @ 0x0000000027c11390 16. ./build_docker/./src/DataTypes/Serializations/SerializationString.cpp:259: DB::SerializationString::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x0000000027c0ec00 17. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:0: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x0000000027aa00db 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>>>*) @ 0x000000002c7b254b 19. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7eb79e 20. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:118: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7c9d8a 21. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x000000002c7e0473 22. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x000000002c7dbec3 23. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x000000002c7dbd35 24. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:0: DB::MergeTreeReadTask::read(DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002c82d05b 25. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:53: DB::MergeTreeInOrderSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&, DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002dea5374 26. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:0: DB::MergeTreeSelectProcessor::read() @ 0x000000002c8242f9 27. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000002de6d77a 28. ./build_docker/./src/Processors/ISource.cpp:0: DB::ISource::work() @ 0x000000002d3290a1 29. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 30. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 31. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:381: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000002d34bd35 2025.09.09 14:56:16.590836 [ 3722 ] {5d17ca9e-a617-4763-95f5-096040654ea5} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=9, jobs=0): (while reading column query_id): (while reading from part /var/lib/clickhouse/store/969/96984bc5-93f4-461f-9504-9500ec594f44/202509_1_1_0/ in table system.filesystem_cache_log (96984bc5-93f4-461f-9504-9500ec594f44) located on disk default of type local, from mark 0 with max_rows_to_read = 83): 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af80b71 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80746 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000266005a2 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000265fffb4 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:1197: ? @ 0x00000000265fd4e7 9. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:62: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x00000000265e6fbd 10. ./contrib/llvm-project/libcxx/include/future:1123: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x00000000265e7bb3 11. DB::ReadBuffer::next() @ 0x000000000b528aeb 12. ./src/IO/ReadBuffer.h:0: DB::CompressedReadBufferBase::readCompressedData(unsigned long&, unsigned long&, bool) @ 0x000000002775f11b 13. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:22: DB::CompressedReadBufferFromFile::nextImpl() @ 0x0000000027763d41 14. DB::ReadBuffer::next() @ 0x000000000b528aeb 15. ./build_docker/./src/DataTypes/Serializations/SerializationString.cpp:159: void DB::deserializeBinarySSE2<1>(DB::PODArray, 63ul, 64ul>&, DB::PODArray, 63ul, 64ul>&, DB::ReadBuffer&, unsigned long) @ 0x0000000027c11390 16. ./build_docker/./src/DataTypes/Serializations/SerializationString.cpp:259: DB::SerializationString::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x0000000027c0ec00 17. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:0: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x0000000027aa00db 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>>>*) @ 0x000000002c7b254b 19. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7eb79e 20. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:118: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7c9d8a 21. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x000000002c7e0473 22. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x000000002c7dbec3 23. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x000000002c7dbd35 24. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:0: DB::MergeTreeReadTask::read(DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002c82d05b 25. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:53: DB::MergeTreeInOrderSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&, DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002dea5374 26. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:0: DB::MergeTreeSelectProcessor::read() @ 0x000000002c8242f9 27. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000002de6d77a 28. ./build_docker/./src/Processors/ISource.cpp:0: DB::ISource::work() @ 0x000000002d3290a1 29. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 30. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 31. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:381: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000002d34bd35 2025.09.09 14:56:16.940651 [ 4022 ] {25aa98b2-6200-46bd-b592-c296eca01808} executeQuery: Code: 42. DB::Exception: Function 'in' expects 2 arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:54600) (comment: 02918_analyzer_to_ast_crash.sql) (in query: WITH x AS (SELECT in((SELECT * FROM y))), y AS (SELECT 1) SELECT * FROM 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x000000000aafc574 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2859: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002839d5b4 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000028367bce 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028366290 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283b62c9 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002835ae03 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3783: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000283679cf 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5153: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000283ba3b9 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002835ad09 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000028359104 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000028357f0d 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002921bdcc 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&) @ 0x000000002941f313 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&) @ 0x0000000029419aef 17. ./contrib/llvm-project/libcxx/include/vector:432: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000029421f5d 18. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000029344c1b 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*) @ 0x0000000029b3703b 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 21. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 22. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 26. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 27. asan_thread_start(void*) @ 0x000000000aa43059 28. ? @ 0x00007f35aab92ac3 29. ? @ 0x00007f35aac24850 2025.09.09 14:56:16.951771 [ 4022 ] {25aa98b2-6200-46bd-b592-c296eca01808} TCPHandler: Code: 42. DB::Exception: Function 'in' expects 2 arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x000000000aafc574 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2859: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002839d5b4 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000028367bce 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028366290 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283b62c9 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002835ae03 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3783: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000283679cf 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5153: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000283ba3b9 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002835ad09 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000028359104 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000028357f0d 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002921bdcc 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&) @ 0x000000002941f313 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&) @ 0x0000000029419aef 17. ./contrib/llvm-project/libcxx/include/vector:432: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000029421f5d 18. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000029344c1b 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*) @ 0x0000000029b3703b 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 21. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 22. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 26. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 27. asan_thread_start(void*) @ 0x000000000aa43059 28. ? @ 0x00007f35aab92ac3 29. ? @ 0x00007f35aac24850 2025.09.09 14:56:17.321230 [ 3238 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:56:17.326072 [ 3239 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:56:17.675660 [ 5359 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 14:56:18.329436 [ 2736 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:56:18.329562 [ 2752 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:56:18.741759 [ 3722 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 14:56:19.331961 [ 2744 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:56:19.334087 [ 2744 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:56:19.388301 [ 5359 ] {5655166f-1759-4233-9387-b7f9854f91ce} executeQuery: Code: 164. DB::Exception: default: Cannot execute query in readonly mode. (READONLY) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:42488) (comment: 02315_readonly_create_function.sh) (in query: CREATE FUNCTION test_function AS (x) -> x + 1;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: auto bool DB::ContextAccess::checkAccessImplHelper(std::shared_ptr const&, DB::AccessFlags) const::'lambda'(int, FormatStringHelperImpl::type...>, $T&&...)::operator()<>(int, FormatStringHelperImpl::type...>, $T&&...) const @ 0x0000000026dc2c4a 4. ./build_docker/./src/Access/ContextAccess.cpp:0: bool DB::ContextAccess::checkAccessImplHelper(std::shared_ptr const&, DB::AccessFlags) const @ 0x0000000026dc05f8 5. ./build_docker/./src/Access/ContextAccess.cpp:750: bool DB::ContextAccess::checkAccessImplHelper(std::shared_ptr const&, DB::AccessRightsElement const&) const @ 0x0000000026dd5f3b 6. ./build_docker/./src/Access/ContextAccess.cpp:792: DB::ContextAccess::checkAccess(std::shared_ptr const&, DB::AccessRightsElements const&) const @ 0x0000000026d949bc 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkAccess(DB::AccessRightsElements const&) const @ 0x0000000028528da4 8. ./build_docker/./src/Interpreters/InterpreterCreateFunctionQuery.cpp:0: DB::InterpreterCreateFunctionQuery::execute() @ 0x0000000029c3456b 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b382fc 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 14:56:19.404998 [ 5359 ] {5655166f-1759-4233-9387-b7f9854f91ce} TCPHandler: Code: 164. DB::Exception: default: Cannot execute query in readonly mode. (READONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: auto bool DB::ContextAccess::checkAccessImplHelper(std::shared_ptr const&, DB::AccessFlags) const::'lambda'(int, FormatStringHelperImpl::type...>, $T&&...)::operator()<>(int, FormatStringHelperImpl::type...>, $T&&...) const @ 0x0000000026dc2c4a 4. ./build_docker/./src/Access/ContextAccess.cpp:0: bool DB::ContextAccess::checkAccessImplHelper(std::shared_ptr const&, DB::AccessFlags) const @ 0x0000000026dc05f8 5. ./build_docker/./src/Access/ContextAccess.cpp:750: bool DB::ContextAccess::checkAccessImplHelper(std::shared_ptr const&, DB::AccessRightsElement const&) const @ 0x0000000026dd5f3b 6. ./build_docker/./src/Access/ContextAccess.cpp:792: DB::ContextAccess::checkAccess(std::shared_ptr const&, DB::AccessRightsElements const&) const @ 0x0000000026d949bc 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkAccess(DB::AccessRightsElements const&) const @ 0x0000000028528da4 8. ./build_docker/./src/Interpreters/InterpreterCreateFunctionQuery.cpp:0: DB::InterpreterCreateFunctionQuery::execute() @ 0x0000000029c3456b 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b382fc 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 14:56:19.796539 [ 3722 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 14:56:20.334532 [ 2786 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:56:20.336715 [ 2788 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:56:20.849746 [ 5359 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 14:56:21.348232 [ 2800 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:56:21.348845 [ 2812 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:56:21.884448 [ 5359 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 14:56:22.350700 [ 2822 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:56:22.351095 [ 2827 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:56:22.938068 [ 5359 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 14:56:23.353142 [ 2852 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:56:23.353704 [ 2854 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:56:24.022455 [ 5359 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 14:56:24.355331 [ 2877 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:56:24.357134 [ 2876 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:56:25.034951 [ 5359 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 14:56:25.358509 [ 2890 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:56:25.359612 [ 2900 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:56:26.025570 [ 4017 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 14:56:26.360623 [ 2918 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:56:26.361950 [ 2921 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:56:27.019834 [ 3766 ] {} ServerErrorHandler: Code: 210. DB::NetException: Connection reset by peer, while reading from socket (peer: [::ffff:127.0.0.1]:37410, local: [::ffff:127.0.0.3]:9000). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 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&&) @ 0x000000001b0b7a5f 3. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:83: DB::ReadBufferFromPocoSocketBase::socketReceiveBytesImpl(char*, unsigned long) @ 0x000000001b0b6042 4. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:107: DB::ReadBufferFromPocoSocketBase::nextImpl() @ 0x000000001b0b6b84 5. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:103: DB::ReadBufferFromPocoSocketChunked::nextImpl() @ 0x000000002cf045f6 6. DB::ReadBuffer::next() @ 0x000000000b528aeb 7. ./src/IO/ReadBuffer.h:0: void DB::varint_impl::readVarUInt(unsigned long&, DB::ReadBuffer&) @ 0x000000001aea644a 8. ./src/IO/ReadHelpers.h:143: DB::readStringBinary(String&, DB::ReadBuffer&, unsigned long) @ 0x000000001aef6572 9. ./build_docker/./src/Server/TCPHandler.cpp:1653: DB::TCPHandler::receiveAddendum() @ 0x000000002d1869eb 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d174260 11. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 15. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 16. asan_thread_start(void*) @ 0x000000000aa43059 17. ? @ 0x00007f35aab92ac3 18. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:56:27.049445 [ 3651 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 14:56:27.128956 [ 4018 ] {} ServerErrorHandler: Code: 210. DB::NetException: Connection reset by peer, while reading from socket (peer: [::ffff:127.0.0.1]:37418, local: [::ffff:127.0.0.3]:9000). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 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&&) @ 0x000000001b0b7a5f 3. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:83: DB::ReadBufferFromPocoSocketBase::socketReceiveBytesImpl(char*, unsigned long) @ 0x000000001b0b6042 4. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:107: DB::ReadBufferFromPocoSocketBase::nextImpl() @ 0x000000001b0b6b84 5. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:103: DB::ReadBufferFromPocoSocketChunked::nextImpl() @ 0x000000002cf045f6 6. DB::ReadBuffer::next() @ 0x000000000b528aeb 7. ./src/IO/ReadBuffer.h:0: void DB::varint_impl::readVarUInt(unsigned long&, DB::ReadBuffer&) @ 0x000000001aea644a 8. ./src/IO/ReadHelpers.h:143: DB::readStringBinary(String&, DB::ReadBuffer&, unsigned long) @ 0x000000001aef6572 9. ./build_docker/./src/Server/TCPHandler.cpp:1653: DB::TCPHandler::receiveAddendum() @ 0x000000002d1869eb 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d174260 11. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 15. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 16. asan_thread_start(void*) @ 0x000000000aa43059 17. ? @ 0x00007f35aab92ac3 18. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:56:27.338064 [ 12632 ] {} ServerErrorHandler: Code: 210. DB::NetException: Connection reset by peer, while reading from socket (peer: [::ffff:127.0.0.1]:41936, local: [::ffff:127.0.0.5]:9000). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 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&&) @ 0x000000001b0b7a5f 3. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:83: DB::ReadBufferFromPocoSocketBase::socketReceiveBytesImpl(char*, unsigned long) @ 0x000000001b0b6042 4. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:107: DB::ReadBufferFromPocoSocketBase::nextImpl() @ 0x000000001b0b6b84 5. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:103: DB::ReadBufferFromPocoSocketChunked::nextImpl() @ 0x000000002cf045f6 6. DB::ReadBuffer::next() @ 0x000000000b528aeb 7. ./src/IO/ReadBuffer.h:0: void DB::varint_impl::readVarUInt(unsigned long&, DB::ReadBuffer&) @ 0x000000001aea644a 8. ./src/IO/ReadHelpers.h:143: DB::readStringBinary(String&, DB::ReadBuffer&, unsigned long) @ 0x000000001aef6572 9. ./build_docker/./src/Server/TCPHandler.cpp:1653: DB::TCPHandler::receiveAddendum() @ 0x000000002d1869eb 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d174260 11. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 15. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 16. asan_thread_start(void*) @ 0x000000000aa43059 17. ? @ 0x00007f35aab92ac3 18. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:56:27.358515 [ 12633 ] {} ServerErrorHandler: Code: 210. DB::NetException: Connection reset by peer, while reading from socket (peer: [::ffff:127.0.0.1]:47892, local: [::ffff:127.0.0.6]:9000). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 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&&) @ 0x000000001b0b7a5f 3. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:83: DB::ReadBufferFromPocoSocketBase::socketReceiveBytesImpl(char*, unsigned long) @ 0x000000001b0b6042 4. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:107: DB::ReadBufferFromPocoSocketBase::nextImpl() @ 0x000000001b0b6b84 5. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:103: DB::ReadBufferFromPocoSocketChunked::nextImpl() @ 0x000000002cf045f6 6. DB::ReadBuffer::next() @ 0x000000000b528aeb 7. ./src/IO/ReadBuffer.h:0: void DB::varint_impl::readVarUInt(unsigned long&, DB::ReadBuffer&) @ 0x000000001aea644a 8. ./src/IO/ReadHelpers.h:143: DB::readStringBinary(String&, DB::ReadBuffer&, unsigned long) @ 0x000000001aef6572 9. ./build_docker/./src/Server/TCPHandler.cpp:1653: DB::TCPHandler::receiveAddendum() @ 0x000000002d1869eb 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d174260 11. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 15. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 16. asan_thread_start(void*) @ 0x000000000aa43059 17. ? @ 0x00007f35aab92ac3 18. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:56:27.363266 [ 4023 ] {3660b9bb-0181-40a5-a617-939361555c17} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=773, jobs=737). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:33378) (comment: 03164_parallel_replicas_range_filter_min_max.sql) (in query: SELECT `__table1`.`k` AS `k` FROM `test_3`.`range_filter_custom_range_test_2` AS `__table1` WHERE (`k` >= 11) AND (`k` < 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af872f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af7b2d1 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af7c3f3 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d36920d 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000002d369e5f 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processOrdinaryQuery() @ 0x000000002d18af7b 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d17644a 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 15. asan_thread_start(void*) @ 0x000000000aa43059 16. ? @ 0x00007f35aab92ac3 17. ? @ 0x00007f35aac24850 2025.09.09 14:56:27.363966 [ 2942 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:56:27.364383 [ 2944 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:56:27.367330 [ 4023 ] {3660b9bb-0181-40a5-a617-939361555c17} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=773, 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af872f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af7b2d1 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af7c3f3 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d36920d 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000002d369e5f 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processOrdinaryQuery() @ 0x000000002d18af7b 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d17644a 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 15. asan_thread_start(void*) @ 0x000000000aa43059 16. ? @ 0x00007f35aab92ac3 17. ? @ 0x00007f35aac24850 2025.09.09 14:56:27.384904 [ 3604 ] {} ServerErrorHandler: Code: 210. DB::NetException: Connection reset by peer, while reading from socket (peer: [::ffff:127.0.0.1]:46622, local: [::ffff:127.0.0.7]:9000). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 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&&) @ 0x000000001b0b7a5f 3. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:83: DB::ReadBufferFromPocoSocketBase::socketReceiveBytesImpl(char*, unsigned long) @ 0x000000001b0b6042 4. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:107: DB::ReadBufferFromPocoSocketBase::nextImpl() @ 0x000000001b0b6b84 5. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:103: DB::ReadBufferFromPocoSocketChunked::nextImpl() @ 0x000000002cf045f6 6. DB::ReadBuffer::next() @ 0x000000000b528aeb 7. ./build_docker/./src/Server/TCPHandler.cpp:383: DB::TCPHandler::runImpl() @ 0x000000002d174fd3 8. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 12. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 13. asan_thread_start(void*) @ 0x000000000aa43059 14. ? @ 0x00007f35aab92ac3 15. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:56:27.459191 [ 3722 ] {8dab0005-11d3-4bf8-a272-a2f5afb6636d} executeQuery: Code: 439. DB::Exception: Received from 127.0.0.8:9000. DB::Exception: Cannot schedule a task: fault injected (threads=773, jobs=737). Stack trace: 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af872f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af7b2d1 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af7c3f3 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d36920d 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000002d369e5f 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processOrdinaryQuery() @ 0x000000002d18af7b 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d17644a 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 15. asan_thread_start(void*) @ 0x000000000aa43059 16. ? @ 0x00007f35aab92ac3 17. ? @ 0x00007f35aac24850 : While executing Remote. (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:42526) (comment: 03164_parallel_replicas_range_filter_min_max.sql) (in query: SELECT count() FROM ( SELECT * FROM cluster(parallel_replicas, currentDatabase(), range_filter_custom_range_test_2) SETTINGS prefer_localhost_replica = 0, max_parallel_replicas = 12, distributed_group_by_no_merge = 0, enable_parallel_replicas = 1, parallel_replicas_custom_key = 'k', parallel_replicas_mode = 'custom_key_range', parallel_replicas_custom_key_range_lower = 0, parallel_replicas_custom_key_range_upper = 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. ./contrib/llvm-project/libcxx/include/string:1499: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x000000001aeb974e 3. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::Connection::receiveException() const @ 0x000000002cee6c6a 4. ./build_docker/./src/Client/Connection.cpp:0: DB::Connection::receivePacket() @ 0x000000002cef780e 5. ./build_docker/./src/Client/PacketReceiver.cpp:0: DB::PacketReceiver::Task::run(std::function, std::function) @ 0x000000002cf9767e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000278ab436 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000278aaa44 8. ./contrib/boost/boost/context/fiber_ucontext.hpp:82: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x00000000278a8394 2025.09.09 14:56:27.463638 [ 4025 ] {} ServerErrorHandler: Code: 210. DB::NetException: Connection reset by peer, while reading from socket (peer: [::ffff:127.0.0.1]:51272, local: [::ffff:127.0.0.1]:9000). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 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&&) @ 0x000000001b0b7a5f 3. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:83: DB::ReadBufferFromPocoSocketBase::socketReceiveBytesImpl(char*, unsigned long) @ 0x000000001b0b6042 4. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:107: DB::ReadBufferFromPocoSocketBase::nextImpl() @ 0x000000001b0b6b84 5. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:103: DB::ReadBufferFromPocoSocketChunked::nextImpl() @ 0x000000002cf045f6 6. DB::ReadBuffer::next() @ 0x000000000b528aeb 7. ./build_docker/./src/Server/TCPHandler.cpp:383: DB::TCPHandler::runImpl() @ 0x000000002d174fd3 8. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 12. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 13. asan_thread_start(void*) @ 0x000000000aa43059 14. ? @ 0x00007f35aab92ac3 15. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:56:27.475965 [ 3722 ] {8dab0005-11d3-4bf8-a272-a2f5afb6636d} TCPHandler: Code: 439. DB::Exception: Received from 127.0.0.8:9000. DB::Exception: Cannot schedule a task: fault injected (threads=773, jobs=737). Stack trace: 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af872f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af7b2d1 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af7c3f3 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d36920d 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000002d369e5f 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processOrdinaryQuery() @ 0x000000002d18af7b 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d17644a 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 15. asan_thread_start(void*) @ 0x000000000aa43059 16. ? @ 0x00007f35aab92ac3 17. ? @ 0x00007f35aac24850 : 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. ./contrib/llvm-project/libcxx/include/string:1499: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x000000001aeb974e 3. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::Connection::receiveException() const @ 0x000000002cee6c6a 4. ./build_docker/./src/Client/Connection.cpp:0: DB::Connection::receivePacket() @ 0x000000002cef780e 5. ./build_docker/./src/Client/PacketReceiver.cpp:0: DB::PacketReceiver::Task::run(std::function, std::function) @ 0x000000002cf9767e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000278ab436 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000278aaa44 8. ./contrib/boost/boost/context/fiber_ucontext.hpp:82: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x00000000278a8394 2025.09.09 14:56:28.125424 [ 3722 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 14:56:28.366338 [ 2967 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:56:28.366594 [ 2966 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:56:29.145788 [ 3722 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 14:56:29.368442 [ 2999 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:56:29.368756 [ 3002 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:56:29.750081 [ 4018 ] {8ae86486-ec83-4178-9307-16800c7314da} executeQuery: Code: 70. DB::Exception: Value in column Int256 cannot be safely converted into type Int32: while executing 'FUNCTION in(i :: 0, __set_2254311728143836420_8721025920488277921 :: 1) -> in(__table1.i, __set_2254311728143836420_8721025920488277921) Nullable(UInt8) : 2'. (CANNOT_CONVERT_TYPE) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:51912) (comment: 02809_storage_set_analysis_bug.sql) (in query: SELECT count() = 1 FROM null_in__fuzz_6 PREWHERE 71 WHERE i IN (test_set);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa91e9a 4. bool DB::callOnIndexAndDataType, std::function::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)> DB::(anonymous namespace)::FunctionCast::createWrapper>(std::shared_ptr const&, DB::DataTypeNumber const*, bool) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)::operator()(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) const::'lambda'(DB::DataTypeNumber const&)>(DB::TypeIndex, std::function::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)> DB::(anonymous namespace)::FunctionCast::createWrapper>(std::shared_ptr const&, DB::DataTypeNumber const*, bool) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)::operator()(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) const::'lambda'(DB::DataTypeNumber const&)&&) @ 0x000000000aef7bc3 5. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)> DB::(anonymous namespace)::FunctionCast::createWrapper>(std::shared_ptr const&, DB::DataTypeNumber 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) @ 0x000000000aee7b63 6. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl const&, std::shared_ptr const&, bool) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x000000000b2fe141 7. DB::(anonymous namespace)::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000acf2e8b 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000cccce5b 9. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccce7e4 10. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd2030 11. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000aac7d8f 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::castColumn(DB::CastType, DB::ColumnWithTypeAndName const&, std::shared_ptr const&, DB::InternalCastFunctionCache*) @ 0x0000000029a9f39d 13. ./build_docker/./src/Interpreters/castColumn.cpp:49: DB::castColumnAccurate(DB::ColumnWithTypeAndName const&, std::shared_ptr const&, DB::InternalCastFunctionCache*) @ 0x0000000029aa01dc 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::Set::execute(std::vector> const&, bool) const @ 0x000000002967342d 15. DB::(anonymous namespace)::FunctionIn::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000121b2b84 16. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aac9135 17. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000cccce5b 18. DB::IExecutableFunction::defaultImplementationForNulls(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000cccd6ee 19. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccccc64 20. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccce65c 21. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd2030 22. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x00000000286fc2bd 23. ./build_docker/./src/Processors/Transforms/FilterTransform.cpp:0: DB::FilterTransform::doTransform(DB::Chunk&) @ 0x000000002d9cbdf4 24. ./build_docker/./src/Processors/Transforms/FilterTransform.cpp:119: DB::FilterTransform::transform(DB::Chunk&) @ 0x000000002d9cb9ee 25. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 26. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 27. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 28. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 29. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:381: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000002d34bd35 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7eaf0 31. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001af8a79f 2025.09.09 14:56:29.754014 [ 4020 ] {} ServerErrorHandler: Code: 210. DB::NetException: Connection reset by peer, while reading from socket (peer: [::ffff:127.0.0.1]:34916, local: [::ffff:127.0.0.9]: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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 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&&) @ 0x000000001b0b7a5f 3. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:83: DB::ReadBufferFromPocoSocketBase::socketReceiveBytesImpl(char*, unsigned long) @ 0x000000001b0b6042 4. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:107: DB::ReadBufferFromPocoSocketBase::nextImpl() @ 0x000000001b0b6b84 5. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:103: DB::ReadBufferFromPocoSocketChunked::nextImpl() @ 0x000000002cf045f6 6. DB::ReadBuffer::next() @ 0x000000000b528aeb 7. ./build_docker/./src/Server/TCPHandler.cpp:383: DB::TCPHandler::runImpl() @ 0x000000002d174fd3 8. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 12. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 13. asan_thread_start(void*) @ 0x000000000aa43059 14. ? @ 0x00007f35aab92ac3 15. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:56:29.760402 [ 4018 ] {8ae86486-ec83-4178-9307-16800c7314da} TCPHandler: Code: 70. DB::Exception: Value in column Int256 cannot be safely converted into type Int32: while executing 'FUNCTION in(i :: 0, __set_2254311728143836420_8721025920488277921 :: 1) -> in(__table1.i, __set_2254311728143836420_8721025920488277921) Nullable(UInt8) : 2'. (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa91e9a 4. bool DB::callOnIndexAndDataType, std::function::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)> DB::(anonymous namespace)::FunctionCast::createWrapper>(std::shared_ptr const&, DB::DataTypeNumber const*, bool) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)::operator()(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) const::'lambda'(DB::DataTypeNumber const&)>(DB::TypeIndex, std::function::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)> DB::(anonymous namespace)::FunctionCast::createWrapper>(std::shared_ptr const&, DB::DataTypeNumber const*, bool) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)::operator()(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) const::'lambda'(DB::DataTypeNumber const&)&&) @ 0x000000000aef7bc3 5. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)> DB::(anonymous namespace)::FunctionCast::createWrapper>(std::shared_ptr const&, DB::DataTypeNumber 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) @ 0x000000000aee7b63 6. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl const&, std::shared_ptr const&, bool) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x000000000b2fe141 7. DB::(anonymous namespace)::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000acf2e8b 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000cccce5b 9. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccce7e4 10. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd2030 11. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000aac7d8f 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::castColumn(DB::CastType, DB::ColumnWithTypeAndName const&, std::shared_ptr const&, DB::InternalCastFunctionCache*) @ 0x0000000029a9f39d 13. ./build_docker/./src/Interpreters/castColumn.cpp:49: DB::castColumnAccurate(DB::ColumnWithTypeAndName const&, std::shared_ptr const&, DB::InternalCastFunctionCache*) @ 0x0000000029aa01dc 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::Set::execute(std::vector> const&, bool) const @ 0x000000002967342d 15. DB::(anonymous namespace)::FunctionIn::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000121b2b84 16. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aac9135 17. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000cccce5b 18. DB::IExecutableFunction::defaultImplementationForNulls(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000cccd6ee 19. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccccc64 20. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccce65c 21. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd2030 22. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x00000000286fc2bd 23. ./build_docker/./src/Processors/Transforms/FilterTransform.cpp:0: DB::FilterTransform::doTransform(DB::Chunk&) @ 0x000000002d9cbdf4 24. ./build_docker/./src/Processors/Transforms/FilterTransform.cpp:119: DB::FilterTransform::transform(DB::Chunk&) @ 0x000000002d9cb9ee 25. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 26. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 27. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 28. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 29. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:381: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000002d34bd35 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7eaf0 31. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001af8a79f 2025.09.09 14:56:30.207164 [ 4023 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 14:56:30.370549 [ 3034 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:56:30.375854 [ 3033 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:56:31.278104 [ 4025 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 14:56:31.373737 [ 3057 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:56:31.378060 [ 3064 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:56:32.269067 [ 4025 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 14:56:32.375917 [ 3095 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:56:32.380575 [ 3097 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:56:33.351457 [ 4025 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 14:56:33.378265 [ 3116 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:56:33.411488 [ 3119 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:56:34.380435 [ 3138 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:56:34.414738 [ 3139 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:56:34.473406 [ 12633 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 14:56:35.043627 [ 3612 ] {} DynamicQueryHandler: Code: 452. DB::Exception: Setting max_execution_time shouldn't be greater than 60. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x0000000026f841fa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:368: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f81de0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/find_if.h:25: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f808a4 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000002d065739 10. ./build_docker/./src/Server/HTTPHandler.cpp:705: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000002d06d139 11. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000002d1cc337 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 15. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 16. asan_thread_start(void*) @ 0x000000000aa43059 17. ? @ 0x00007f35aab92ac3 18. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:56:35.382875 [ 3167 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:56:35.416434 [ 3172 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:56:35.555528 [ 4025 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 14:56:36.385414 [ 3190 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:56:36.418645 [ 3191 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:56:36.510060 [ 4025 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 14:56:36.544211 [ 3612 ] {} DynamicQueryHandler: Code: 452. DB::Exception: Setting max_execution_time shouldn't be greater than 60. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x0000000026f841fa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:368: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f81de0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/find_if.h:25: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f808a4 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000002d065739 10. ./build_docker/./src/Server/HTTPHandler.cpp:705: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000002d06d139 11. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000002d1cc337 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 15. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 16. asan_thread_start(void*) @ 0x000000000aa43059 17. ? @ 0x00007f35aab92ac3 18. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:56:36.730544 [ 4023 ] {dd9aeafd-9f7a-40be-8fc7-5a84d8d556e4} executeQuery: Code: 48. DB::Exception: Truncate is not supported by storage Null. (NOT_IMPLEMENTED) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:51948) (comment: 03008_deduplication_remote_insert_select.sql) (in query: DROP TABLE dst_null;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::IStorage::truncate(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, DB::TableExclusiveLockHolder&) @ 0x00000000260e9270 4. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:279: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x00000000291f066f 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x00000000291ed665 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x00000000291ebd68 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x00000000291eb7ed 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b382fc 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 11. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 15. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 16. asan_thread_start(void*) @ 0x000000000aa43059 17. ? @ 0x00007f35aab92ac3 18. ? @ 0x00007f35aac24850 2025.09.09 14:56:36.733764 [ 4023 ] {dd9aeafd-9f7a-40be-8fc7-5a84d8d556e4} 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::IStorage::truncate(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, DB::TableExclusiveLockHolder&) @ 0x00000000260e9270 4. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:279: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x00000000291f066f 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x00000000291ed665 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x00000000291ebd68 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x00000000291eb7ed 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b382fc 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 11. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 15. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 16. asan_thread_start(void*) @ 0x000000000aa43059 17. ? @ 0x00007f35aab92ac3 18. ? @ 0x00007f35aac24850 2025.09.09 14:56:37.387546 [ 3215 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:56:37.420841 [ 3216 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:56:37.536198 [ 4023 ] {0e150e76-d13c-44e6-8793-53849a09a5fb} executeQuery: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:52038) (comment: 01353_low_cardinality_join_types.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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x0000000026f807e3 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x000000002853b6ad 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterSetQuery::execute() @ 0x00000000294f603b 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b382fc 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 14:56:37.539914 [ 4023 ] {0e150e76-d13c-44e6-8793-53849a09a5fb} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x0000000026f807e3 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x000000002853b6ad 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterSetQuery::execute() @ 0x00000000294f603b 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b382fc 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 14:56:37.563572 [ 4025 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 14:56:38.389644 [ 2738 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:56:38.423349 [ 2736 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:56:38.716560 [ 4025 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 14:56:39.397559 [ 2768 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:56:39.426044 [ 2770 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:56:39.690517 [ 4025 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 14:56:40.399689 [ 2797 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:56:40.429105 [ 2799 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:56:40.674726 [ 4025 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 14:56:41.401914 [ 2826 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:56:41.431321 [ 2824 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:56:41.652181 [ 4025 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 14:56:42.403953 [ 2848 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:56:42.433641 [ 2850 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:56:42.739305 [ 4025 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 14:56:43.406360 [ 2872 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:56:43.435817 [ 2870 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:56:43.679251 [ 4025 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 14:56:44.408447 [ 2898 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:56:44.437748 [ 2900 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:56:44.681020 [ 4025 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 14:56:45.115228 [ 3612 ] {} DynamicQueryHandler: Code: 452. DB::Exception: Setting max_execution_time shouldn't be greater than 60. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x0000000026f841fa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:368: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f81de0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/find_if.h:25: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f808a4 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000002d065739 10. ./build_docker/./src/Server/HTTPHandler.cpp:705: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000002d06d139 11. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000002d1cc337 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 15. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 16. asan_thread_start(void*) @ 0x000000000aa43059 17. ? @ 0x00007f35aab92ac3 18. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:56:45.411148 [ 2921 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:56:45.439807 [ 2920 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:56:45.678432 [ 4025 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 14:56:46.414415 [ 2943 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:56:46.442646 [ 2945 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:56:46.733271 [ 4025 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 14:56:47.416973 [ 2971 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:56:47.446728 [ 2975 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:56:47.796684 [ 4025 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 14:56:48.419179 [ 2997 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:56:48.449001 [ 2993 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:56:48.928214 [ 4025 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 14:56:49.421602 [ 3012 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:56:49.451342 [ 3009 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:56:49.951552 [ 4025 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 14:56:50.423916 [ 3033 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:56:50.453465 [ 3039 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:56:50.910978 [ 4025 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 14:56:51.426378 [ 3059 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:56:51.455776 [ 3057 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:56:51.995462 [ 4025 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 14:56:52.428716 [ 3086 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:56:52.458950 [ 3081 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:56:52.969629 [ 4025 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 14:56:53.431549 [ 3101 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:56:53.461570 [ 3100 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:56:54.086283 [ 4025 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 14:56:54.434040 [ 3115 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:56:54.463911 [ 3118 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:56:55.147865 [ 4025 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 14:56:55.436169 [ 3136 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:56:55.466139 [ 3145 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:56:56.141051 [ 4025 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 14:56:56.438639 [ 3154 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:56:56.468402 [ 3157 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:56:57.090114 [ 4025 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 14:56:57.441074 [ 3169 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:56:57.470627 [ 3175 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:56:58.117088 [ 4025 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 14:56:58.443357 [ 3190 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:56:58.472721 [ 3196 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:56:59.159003 [ 4025 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 14:56:59.445629 [ 3197 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:56:59.474924 [ 3203 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:57:00.158633 [ 4025 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 14:57:00.448186 [ 3218 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:57:00.477086 [ 3225 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:57:01.133490 [ 4025 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 14:57:01.450465 [ 3239 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:57:01.479646 [ 3243 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:57:02.133755 [ 4025 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 14:57:02.452935 [ 2749 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:57:02.482034 [ 2759 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:57:03.119352 [ 4025 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 14:57:03.455626 [ 2744 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:57:03.484641 [ 2766 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:57:04.235524 [ 4025 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 14:57:04.400347 [ 3329 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {b2866e3d-697f-407e-a02c-018043ee7457::202509_1_76_15}: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=13, jobs=0). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af80b71 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80746 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002c765aab 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:1197: ? @ 0x000000002c7602b8 8. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x000000002c75fc2b 9. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:0: DB::MergeTreeReaderCompact::MergeTreeReaderCompact(std::shared_ptr, DB::NamesAndTypesList, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*, DB::MarkCache*, DB::MarkRanges, DB::MergeTreeReaderSettings, std::map, std::allocator>>, std::function const&, int) @ 0x000000002c7aee03 10. ./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.h:16: DB::MergeTreeReaderCompactSingleBuffer::MergeTreeReaderCompactSingleBuffer&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int&&) @ 0x000000002c5d6d21 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::MergeTreeDataPartCompact::getReader(DB::NamesAndTypesList const&, std::shared_ptr const&, DB::MarkRanges const&, std::unordered_map, std::equal_to, std::allocator>> const&, DB::UncompressedCache*, DB::MarkCache*, std::shared_ptr const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) const @ 0x000000002c5d1037 12. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:169: DB::MergeTreeSequentialSource::MergeTreeSequentialSource(DB::MergeTreeSequentialSourceType, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::vector>, std::optional, bool, bool, bool) @ 0x000000002c80c330 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:35: DB::MergeTreeSequentialSource* std::construct_at[abi:v15007] const&, std::shared_ptr&, std::shared_ptr&, std::vector>&, std::optional, bool, bool&, bool&, DB::MergeTreeSequentialSource*>(DB::MergeTreeSequentialSource*, DB::MergeTreeSequentialSourceType&, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr&, std::shared_ptr&, std::vector>&, std::optional&&, bool&&, bool&, bool&) @ 0x000000002c81320f 14. ./contrib/llvm-project/libcxx/include/__memory/allocator_traits.h:298: DB::createMergeTreeSequentialSource(DB::MergeTreeSequentialSourceType, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::vector>, std::optional, std::shared_ptr>, bool, bool, bool) @ 0x000000002c810812 15. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1136: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::createMergedStream() @ 0x000000002c3dd079 16. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() @ 0x000000002c3d6516 17. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:534: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x000000002c3e2799 18. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::execute() @ 0x000000002c3ef3fe 19. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:0: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000002cc2f4c0 20. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000002c427f28 21. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000002c429675 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7eaf0 23. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001af8a79f 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 26. asan_thread_start(void*) @ 0x000000000aa43059 27. ? @ 0x00007f35aab92ac3 28. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:57:04.457924 [ 2789 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:57:04.487273 [ 2790 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:57:05.178809 [ 3612 ] {} DynamicQueryHandler: Code: 452. DB::Exception: Setting max_execution_time shouldn't be greater than 60. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x0000000026f841fa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:368: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f81de0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/find_if.h:25: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f808a4 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000002d065739 10. ./build_docker/./src/Server/HTTPHandler.cpp:705: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000002d06d139 11. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000002d1cc337 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 15. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 16. asan_thread_start(void*) @ 0x000000000aa43059 17. ? @ 0x00007f35aab92ac3 18. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:57:05.269210 [ 4025 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 14:57:05.460284 [ 2803 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:57:05.489926 [ 2798 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:57:06.255370 [ 4025 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 14:57:06.462653 [ 2824 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:57:06.492426 [ 2830 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:57:07.285267 [ 4025 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 14:57:07.464970 [ 2837 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:57:07.494873 [ 2842 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:57:08.264462 [ 4025 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 14:57:08.474809 [ 2859 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:57:08.497196 [ 2857 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:57:09.302537 [ 4025 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 14:57:09.476959 [ 2874 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:57:09.499531 [ 2886 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:57:10.329195 [ 4025 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 14:57:10.479132 [ 2897 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:57:10.501679 [ 2895 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:57:11.319685 [ 4025 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 14:57:11.481040 [ 2912 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:57:11.503747 [ 2905 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:57:12.341337 [ 4025 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 14:57:12.483261 [ 2924 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:57:12.506137 [ 2929 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:57:13.311560 [ 4025 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 14:57:13.485474 [ 2946 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:57:13.508299 [ 2945 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:57:14.301146 [ 4025 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 14:57:14.487636 [ 2963 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:57:14.516124 [ 2964 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:57:15.312894 [ 4025 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 14:57:15.489825 [ 2988 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:57:15.518260 [ 2986 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:57:16.364135 [ 4025 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 14:57:16.492104 [ 2995 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:57:16.520379 [ 2999 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:57:17.414933 [ 4025 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 14:57:17.494386 [ 3010 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:57:17.524027 [ 3018 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:57:18.496563 [ 3034 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:57:18.526306 [ 3033 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:57:18.530218 [ 4025 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 14:57:19.498900 [ 3045 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:57:19.528794 [ 3053 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:57:19.540895 [ 4025 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 14:57:20.501001 [ 3073 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:57:20.531073 [ 3066 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:57:20.567382 [ 4025 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 14:57:21.503260 [ 3074 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:57:21.529726 [ 4025 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 14:57:21.533274 [ 3086 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:57:22.505528 [ 3105 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:57:22.543622 [ 3106 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:57:22.579963 [ 4025 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 14:57:23.508278 [ 3116 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:57:23.546049 [ 3115 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:57:23.635709 [ 4025 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 14:57:24.510729 [ 3126 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:57:24.548543 [ 3133 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:57:24.689677 [ 4025 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 14:57:25.512997 [ 3146 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:57:25.583862 [ 3128 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:57:25.701262 [ 4025 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 14:57:26.515439 [ 3158 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:57:26.588323 [ 3167 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:57:26.643456 [ 3612 ] {} DynamicQueryHandler: Code: 452. DB::Exception: Setting max_execution_time shouldn't be greater than 60. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x0000000026f841fa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:368: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f81de0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/find_if.h:25: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f808a4 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000002d065739 10. ./build_docker/./src/Server/HTTPHandler.cpp:705: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000002d06d139 11. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000002d1cc337 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 15. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 16. asan_thread_start(void*) @ 0x000000000aa43059 17. ? @ 0x00007f35aab92ac3 18. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:57:26.773807 [ 4025 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 14:57:27.518077 [ 3164 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:57:27.591791 [ 3171 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:57:27.816894 [ 4025 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 14:57:28.541502 [ 3192 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:57:28.594079 [ 3188 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:57:28.824401 [ 4025 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 14:57:29.544077 [ 3213 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:57:29.596674 [ 3210 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:57:29.837519 [ 4025 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 14:57:30.546760 [ 3218 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:57:30.598931 [ 3233 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:57:30.848392 [ 4025 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 14:57:31.558456 [ 2747 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:57:31.601403 [ 2754 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:57:31.849184 [ 4025 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 14:57:32.561235 [ 2759 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:57:32.603706 [ 2762 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:57:32.821183 [ 4025 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 14:57:33.570404 [ 2770 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:57:33.606170 [ 2775 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:57:33.878345 [ 4025 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 14:57:34.575320 [ 2794 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:57:34.608623 [ 2792 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:57:34.901112 [ 4025 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 14:57:35.233089 [ 3612 ] {} DynamicQueryHandler: Code: 452. DB::Exception: Setting max_execution_time shouldn't be greater than 60. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x0000000026f841fa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:368: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f81de0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/find_if.h:25: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f808a4 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000002d065739 10. ./build_docker/./src/Server/HTTPHandler.cpp:705: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000002d06d139 11. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000002d1cc337 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 15. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 16. asan_thread_start(void*) @ 0x000000000aa43059 17. ? @ 0x00007f35aab92ac3 18. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:57:35.578070 [ 2798 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:57:35.611089 [ 2811 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:57:35.922102 [ 4025 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 14:57:36.580833 [ 2830 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:57:36.614032 [ 2819 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:57:36.970240 [ 4025 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 14:57:37.583285 [ 2833 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:57:37.616722 [ 2835 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:57:37.989264 [ 4025 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 14:57:38.585906 [ 2856 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:57:38.618893 [ 2869 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:57:38.998548 [ 4025 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 14:57:39.588077 [ 2870 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:57:39.621200 [ 2874 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:57:39.981461 [ 4025 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 14:57:40.610785 [ 2890 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:57:40.626948 [ 2900 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:57:41.024427 [ 4025 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 14:57:41.613176 [ 2915 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:57:41.629469 [ 2914 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:57:42.017923 [ 4025 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 14:57:42.615555 [ 2930 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:57:42.631765 [ 2929 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:57:43.077864 [ 4025 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 14:57:43.617793 [ 2942 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:57:43.633823 [ 2944 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:57:44.239104 [ 4025 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 14:57:44.619972 [ 2955 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:57:44.637040 [ 2958 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:57:45.222583 [ 4025 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 14:57:45.623024 [ 2980 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:57:45.639556 [ 2978 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:57:46.218031 [ 4025 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 14:57:46.625607 [ 2987 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:57:46.641964 [ 2999 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:57:47.194567 [ 4025 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 14:57:47.628065 [ 3001 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:57:47.644405 [ 3012 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:57:48.184691 [ 4025 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 14:57:48.630823 [ 3020 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:57:48.646823 [ 3019 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:57:49.329477 [ 4025 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 14:57:49.633427 [ 3041 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:57:49.649473 [ 3042 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:57:50.338795 [ 4025 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 14:57:50.635888 [ 3062 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:57:50.651844 [ 3063 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:57:51.338465 [ 4025 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 14:57:51.654608 [ 3077 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:57:51.638122 [ 3076 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:57:52.374293 [ 4025 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 14:57:52.656923 [ 3090 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:57:52.694946 [ 3091 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:57:53.441084 [ 4025 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 14:57:53.659504 [ 3112 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:57:53.697324 [ 3109 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:57:54.524760 [ 4025 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 14:57:54.661794 [ 3129 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:57:54.699949 [ 3132 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:57:55.600983 [ 4025 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 14:57:55.663910 [ 3128 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:57:55.702238 [ 3148 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:57:56.663006 [ 12632 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 14:57:56.674483 [ 3158 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:57:56.706825 [ 3170 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:57:57.677011 [ 3174 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:57:57.697935 [ 4023 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 14:57:57.708992 [ 3182 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:57:58.679853 [ 3197 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:57:58.711402 [ 3203 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:57:58.786733 [ 4025 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 14:57:59.577588 [ 3325 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {cb913e3a-f414-4872-8c3b-02a3eff4ab8a::202509_1_50_10}: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=13, 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af80b71 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80746 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002c765aab 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:1197: ? @ 0x000000002c7602b8 8. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x000000002c75fc2b 9. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:0: DB::MergeTreeReaderCompact::MergeTreeReaderCompact(std::shared_ptr, DB::NamesAndTypesList, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*, DB::MarkCache*, DB::MarkRanges, DB::MergeTreeReaderSettings, std::map, std::allocator>>, std::function const&, int) @ 0x000000002c7aee03 10. ./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.h:16: DB::MergeTreeReaderCompactSingleBuffer::MergeTreeReaderCompactSingleBuffer&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int&&) @ 0x000000002c5d6d21 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::MergeTreeDataPartCompact::getReader(DB::NamesAndTypesList const&, std::shared_ptr const&, DB::MarkRanges const&, std::unordered_map, std::equal_to, std::allocator>> const&, DB::UncompressedCache*, DB::MarkCache*, std::shared_ptr const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) const @ 0x000000002c5d1037 12. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:169: DB::MergeTreeSequentialSource::MergeTreeSequentialSource(DB::MergeTreeSequentialSourceType, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::vector>, std::optional, bool, bool, bool) @ 0x000000002c80c330 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:35: DB::MergeTreeSequentialSource* std::construct_at[abi:v15007] const&, std::shared_ptr&, std::shared_ptr&, std::vector>&, std::optional, bool, bool&, bool&, DB::MergeTreeSequentialSource*>(DB::MergeTreeSequentialSource*, DB::MergeTreeSequentialSourceType&, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr&, std::shared_ptr&, std::vector>&, std::optional&&, bool&&, bool&, bool&) @ 0x000000002c81320f 14. ./contrib/llvm-project/libcxx/include/__memory/allocator_traits.h:298: DB::createMergeTreeSequentialSource(DB::MergeTreeSequentialSourceType, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::vector>, std::optional, std::shared_ptr>, bool, bool, bool) @ 0x000000002c810812 15. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1136: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::createMergedStream() @ 0x000000002c3dd079 16. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() @ 0x000000002c3d6516 17. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:534: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x000000002c3e2799 18. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::execute() @ 0x000000002c3ef3fe 19. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:0: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000002cc2f4c0 20. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000002c427f28 21. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000002c429675 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7eaf0 23. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001af8a79f 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 26. asan_thread_start(void*) @ 0x000000000aa43059 27. ? @ 0x00007f35aab92ac3 28. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:57:59.682154 [ 3225 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:57:59.713606 [ 3224 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:57:59.779386 [ 4023 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 14:58:00.296821 [ 4023 ] {b348cf03-3332-4738-9026-34eaab1e07d3} executeQuery: Code: 57. DB::Exception: Table test_3.test already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:58972) (comment: 01630_disallow_floating_point_as_partition_key.sql) (in query: CREATE TABLE test (`a` Float32, `b` int) ENGINE = MergeTree PARTITION BY a ORDER BY tuple() SETTINGS index_granularity = 49566, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 0.07942100614309311, replace_long_file_name_to_hash = true, max_file_name_length = 128, min_bytes_for_full_part_storage = 96522102, compact_parts_max_bytes_to_buffer = 504706678, compact_parts_max_granules_to_buffer = 256, compact_parts_merge_max_bytes_to_prefetch_part = 24777948, merge_max_block_size = 18580, old_parts_lifetime = 213., prefer_fetch_merged_part_size_threshold = 10737418240, vertical_merge_algorithm_min_rows_to_activate = 668746, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 9015255735, index_granularity_bytes = 24660092, concurrent_part_removal_threshold = 100, allow_vertical_merges_from_compact_to_wide_parts = true, cache_populated_by_fetch = false, marks_compress_block_size = 38532, primary_key_compress_block_size = 9420), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa91e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1558: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291bc5ff 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291ac835 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000291c3415 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b382fc 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 15. asan_thread_start(void*) @ 0x000000000aa43059 16. ? @ 0x00007f35aab92ac3 17. ? @ 0x00007f35aac24850 2025.09.09 14:58:00.299028 [ 4023 ] {b348cf03-3332-4738-9026-34eaab1e07d3} TCPHandler: Code: 57. DB::Exception: Table test_3.test already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa91e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1558: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291bc5ff 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291ac835 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000291c3415 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b382fc 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 15. asan_thread_start(void*) @ 0x000000000aa43059 16. ? @ 0x00007f35aab92ac3 17. ? @ 0x00007f35aac24850 2025.09.09 14:58:00.684358 [ 2745 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:58:00.716968 [ 2733 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:58:00.873349 [ 4023 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 14:58:01.591766 [ 4025 ] {35d01f83-f52c-41c7-9740-57e7678afc8f} executeQuery: Code: 43. DB::Exception: mapAdd only accepts maps: In scope SELECT mapAdd([1], [1]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:58984) (comment: 01318_map_add_map_subtract.sql) (in query: -- mapAdd select mapAdd([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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000aad4b34 4. DB::(anonymous namespace)::FunctionMapOp<(DB::(anonymous namespace)::OpTypes)0>::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000001a6229c8 5. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x000000000aa8d2f3 6. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000ccd376e 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000ccd3176 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000ccd4343 9. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000028399ff0 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000028367bce 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028366290 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283b62c9 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002835ae03 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000028359104 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000028357f0d 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002921bdcc 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&) @ 0x000000002941f313 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&) @ 0x0000000029419aef 19. ./contrib/llvm-project/libcxx/include/vector:432: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000029421f5d 20. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000029344c1b 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*) @ 0x0000000029b3703b 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 23. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 24. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 29. asan_thread_start(void*) @ 0x000000000aa43059 30. ? @ 0x00007f35aab92ac3 31. ? @ 0x00007f35aac24850 2025.09.09 14:58:01.605440 [ 4025 ] {35d01f83-f52c-41c7-9740-57e7678afc8f} TCPHandler: Code: 43. DB::Exception: mapAdd only accepts maps: In scope SELECT mapAdd([1], [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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000aad4b34 4. DB::(anonymous namespace)::FunctionMapOp<(DB::(anonymous namespace)::OpTypes)0>::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000001a6229c8 5. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x000000000aa8d2f3 6. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000ccd376e 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000ccd3176 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000ccd4343 9. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000028399ff0 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000028367bce 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028366290 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283b62c9 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002835ae03 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000028359104 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000028357f0d 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002921bdcc 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&) @ 0x000000002941f313 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&) @ 0x0000000029419aef 19. ./contrib/llvm-project/libcxx/include/vector:432: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000029421f5d 20. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000029344c1b 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*) @ 0x0000000029b3703b 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 23. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 24. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 29. asan_thread_start(void*) @ 0x000000000aa43059 30. ? @ 0x00007f35aab92ac3 31. ? @ 0x00007f35aac24850 2025.09.09 14:58:01.686621 [ 2765 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:58:01.719340 [ 2755 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:58:01.831340 [ 4025 ] {9fbc4813-24b7-4a9e-a540-884e0d3819a3} executeQuery: Code: 42. DB::Exception: mapAdd accepts at least two maps or map tuples: In scope SELECT mapAdd(([1], [1])). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:58984) (comment: 01318_map_add_map_subtract.sql) (in query: select mapAdd(([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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000aad4b34 4. DB::(anonymous namespace)::FunctionMapOp<(DB::(anonymous namespace)::OpTypes)0>::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000001a6228c8 5. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x000000000aa8d2f3 6. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000ccd376e 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000ccd3176 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000ccd4343 9. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000028399ff0 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000028367bce 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028366290 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283b62c9 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002835ae03 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000028359104 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000028357f0d 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002921bdcc 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&) @ 0x000000002941f313 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&) @ 0x0000000029419aef 19. ./contrib/llvm-project/libcxx/include/vector:432: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000029421f5d 20. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000029344c1b 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*) @ 0x0000000029b3703b 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 23. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 24. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 29. asan_thread_start(void*) @ 0x000000000aa43059 30. ? @ 0x00007f35aab92ac3 31. ? @ 0x00007f35aac24850 2025.09.09 14:58:01.834220 [ 4025 ] {9fbc4813-24b7-4a9e-a540-884e0d3819a3} TCPHandler: Code: 42. DB::Exception: mapAdd accepts at least two maps or map tuples: In scope SELECT mapAdd(([1], [1])). (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000aad4b34 4. DB::(anonymous namespace)::FunctionMapOp<(DB::(anonymous namespace)::OpTypes)0>::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000001a6228c8 5. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x000000000aa8d2f3 6. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000ccd376e 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000ccd3176 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000ccd4343 9. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000028399ff0 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000028367bce 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028366290 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283b62c9 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002835ae03 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000028359104 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000028357f0d 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002921bdcc 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&) @ 0x000000002941f313 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&) @ 0x0000000029419aef 19. ./contrib/llvm-project/libcxx/include/vector:432: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000029421f5d 20. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000029344c1b 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*) @ 0x0000000029b3703b 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 23. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 24. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 29. asan_thread_start(void*) @ 0x000000000aa43059 30. ? @ 0x00007f35aab92ac3 31. ? @ 0x00007f35aac24850 2025.09.09 14:58:01.857777 [ 4023 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 14:58:01.988578 [ 4025 ] {65a59f08-6a78-49e2-854b-8a2f10abc6d2} executeQuery: Code: 43. DB::Exception: Expected same UInt8 type for all keys in mapAdd: In scope SELECT mapAdd(([1], [1]), map) FROM tab. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:58984) (comment: 01318_map_add_map_subtract.sql) (in query: select mapAdd(([1], [1]), map) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa91e9a 4. DB::(anonymous namespace)::FunctionMapOp<(DB::(anonymous namespace)::OpTypes)0>::checkTypes(std::shared_ptr&, std::shared_ptr&, std::shared_ptr const&, std::shared_ptr&) const @ 0x000000001a72806e 5. DB::(anonymous namespace)::FunctionMapOp<(DB::(anonymous namespace)::OpTypes)0>::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000001a6211d1 6. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x000000000aa8d2f3 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000ccd376e 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000ccd3176 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000ccd4343 10. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000028399ff0 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000028367bce 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028366290 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283b62c9 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002835ae03 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000028359104 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000028357f0d 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002921bdcc 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&) @ 0x000000002941f313 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&) @ 0x0000000029419aef 20. ./contrib/llvm-project/libcxx/include/vector:432: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000029421f5d 21. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000029344c1b 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*) @ 0x0000000029b3703b 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 25. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 29. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 30. asan_thread_start(void*) @ 0x000000000aa43059 31. ? @ 0x00007f35aab92ac3 2025.09.09 14:58:01.991224 [ 4025 ] {65a59f08-6a78-49e2-854b-8a2f10abc6d2} TCPHandler: Code: 43. DB::Exception: Expected same UInt8 type for all keys in mapAdd: In scope SELECT mapAdd(([1], [1]), map) FROM tab. (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa91e9a 4. DB::(anonymous namespace)::FunctionMapOp<(DB::(anonymous namespace)::OpTypes)0>::checkTypes(std::shared_ptr&, std::shared_ptr&, std::shared_ptr const&, std::shared_ptr&) const @ 0x000000001a72806e 5. DB::(anonymous namespace)::FunctionMapOp<(DB::(anonymous namespace)::OpTypes)0>::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000001a6211d1 6. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x000000000aa8d2f3 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000ccd376e 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000ccd3176 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000ccd4343 10. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000028399ff0 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000028367bce 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028366290 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283b62c9 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002835ae03 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000028359104 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000028357f0d 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002921bdcc 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&) @ 0x000000002941f313 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&) @ 0x0000000029419aef 20. ./contrib/llvm-project/libcxx/include/vector:432: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000029421f5d 21. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000029344c1b 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*) @ 0x0000000029b3703b 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 25. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 29. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 30. asan_thread_start(void*) @ 0x000000000aa43059 31. ? @ 0x00007f35aab92ac3 2025.09.09 14:58:02.186836 [ 4025 ] {690d772b-1298-4aba-829e-5b5eb85d5f71} executeQuery: Code: 43. DB::Exception: All value types in mapAdd should be promotable to UInt64, got Int64: In scope SELECT mapAdd(([toUInt64(1)], [1]), map) FROM tab. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:58984) (comment: 01318_map_add_map_subtract.sql) (in query: select mapAdd(([toUInt64(1)], [1]), map) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000ac6ad20 4. DB::(anonymous namespace)::FunctionMapOp<(DB::(anonymous namespace)::OpTypes)0>::checkTypes(std::shared_ptr&, std::shared_ptr&, std::shared_ptr const&, std::shared_ptr&) const @ 0x000000001a7281c3 5. DB::(anonymous namespace)::FunctionMapOp<(DB::(anonymous namespace)::OpTypes)0>::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000001a6211d1 6. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x000000000aa8d2f3 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000ccd376e 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000ccd3176 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000ccd4343 10. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000028399ff0 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000028367bce 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028366290 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283b62c9 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002835ae03 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000028359104 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000028357f0d 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002921bdcc 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&) @ 0x000000002941f313 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&) @ 0x0000000029419aef 20. ./contrib/llvm-project/libcxx/include/vector:432: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000029421f5d 21. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000029344c1b 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*) @ 0x0000000029b3703b 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 25. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 29. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 30. asan_thread_start(void*) @ 0x000000000aa43059 31. ? @ 0x00007f35aab92ac3 2025.09.09 14:58:02.189148 [ 4025 ] {690d772b-1298-4aba-829e-5b5eb85d5f71} TCPHandler: Code: 43. DB::Exception: All value types in mapAdd should be promotable to UInt64, got Int64: In scope SELECT mapAdd(([toUInt64(1)], [1]), map) FROM tab. (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000ac6ad20 4. DB::(anonymous namespace)::FunctionMapOp<(DB::(anonymous namespace)::OpTypes)0>::checkTypes(std::shared_ptr&, std::shared_ptr&, std::shared_ptr const&, std::shared_ptr&) const @ 0x000000001a7281c3 5. DB::(anonymous namespace)::FunctionMapOp<(DB::(anonymous namespace)::OpTypes)0>::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000001a6211d1 6. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x000000000aa8d2f3 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000ccd376e 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000ccd3176 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000ccd4343 10. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000028399ff0 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000028367bce 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028366290 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283b62c9 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002835ae03 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000028359104 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000028357f0d 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002921bdcc 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&) @ 0x000000002941f313 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&) @ 0x0000000029419aef 20. ./contrib/llvm-project/libcxx/include/vector:432: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000029421f5d 21. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000029344c1b 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*) @ 0x0000000029b3703b 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 25. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 29. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 30. asan_thread_start(void*) @ 0x000000000aa43059 31. ? @ 0x00007f35aab92ac3 2025.09.09 14:58:02.435178 [ 4025 ] {9da822d3-8ac5-4907-a30c-31f52c98518b} executeQuery: Code: 42. DB::Exception: Key and value array should have same amount of elements. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:58984) (comment: 01318_map_add_map_subtract.sql) (in query: select mapAdd(([toUInt64(1), 2], [toInt32(1)]), map) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aac868e 4. DB::(anonymous namespace)::FunctionMapOp<(DB::(anonymous namespace)::OpTypes)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001a62003a 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aa8c635 6. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aac91d5 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000cccccfb 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccce65c 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd2030 10. ./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) @ 0x0000000028259428 11. ./contrib/llvm-project/libcxx/include/vector:961: DB::ActionsDAG::updateHeader(DB::Block const&) const @ 0x0000000028256e17 12. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:10: DB::ExpressionTransform::transformHeader(DB::Block const&, DB::ActionsDAG const&) @ 0x000000002d9c2197 13. ./build_docker/./src/Processors/QueryPlan/ExpressionStep.cpp:0: DB::ExpressionStep::ExpressionStep(DB::DataStream const&, DB::ActionsDAG) @ 0x000000002dd8d279 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::(anonymous namespace)::addExpressionStep(DB::QueryPlan&, std::shared_ptr&, String const&, std::unordered_set, std::hash>, std::equal_to>, std::allocator>>&) @ 0x000000002943bd73 15. ./contrib/llvm-project/libcxx/include/string:1499: DB::Planner::buildPlanForQueryNode() @ 0x0000000029434460 16. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x00000000294261fb 17. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000029421552 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1182: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3737e 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 21. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 25. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 26. asan_thread_start(void*) @ 0x000000000aa43059 27. ? @ 0x00007f35aab92ac3 28. ? @ 0x00007f35aac24850 2025.09.09 14:58:02.437689 [ 4025 ] {9da822d3-8ac5-4907-a30c-31f52c98518b} TCPHandler: Code: 42. DB::Exception: Key and value array should have same amount of elements. (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aac868e 4. DB::(anonymous namespace)::FunctionMapOp<(DB::(anonymous namespace)::OpTypes)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001a62003a 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aa8c635 6. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aac91d5 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000cccccfb 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccce65c 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd2030 10. ./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) @ 0x0000000028259428 11. ./contrib/llvm-project/libcxx/include/vector:961: DB::ActionsDAG::updateHeader(DB::Block const&) const @ 0x0000000028256e17 12. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:10: DB::ExpressionTransform::transformHeader(DB::Block const&, DB::ActionsDAG const&) @ 0x000000002d9c2197 13. ./build_docker/./src/Processors/QueryPlan/ExpressionStep.cpp:0: DB::ExpressionStep::ExpressionStep(DB::DataStream const&, DB::ActionsDAG) @ 0x000000002dd8d279 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::(anonymous namespace)::addExpressionStep(DB::QueryPlan&, std::shared_ptr&, String const&, std::unordered_set, std::hash>, std::equal_to>, std::allocator>>&) @ 0x000000002943bd73 15. ./contrib/llvm-project/libcxx/include/string:1499: DB::Planner::buildPlanForQueryNode() @ 0x0000000029434460 16. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x00000000294261fb 17. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000029421552 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1182: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3737e 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 21. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 25. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 26. asan_thread_start(void*) @ 0x000000000aa43059 27. ? @ 0x00007f35aab92ac3 28. ? @ 0x00007f35aac24850 2025.09.09 14:58:02.689249 [ 2780 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:58:02.721649 [ 2776 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:58:02.819103 [ 4023 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 14:58:03.694033 [ 2802 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:58:03.724460 [ 2800 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:58:03.907871 [ 4023 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 14:58:04.214825 [ 4025 ] {3826989e-9cdc-4b33-8132-a914a7ab6094} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=773, jobs=734). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:58984) (comment: 01318_map_add_map_subtract.sql) (in query: select mapAdd(([toInt32(1), 2], [toInt32(1), 1]), ([toInt32(1), 2], [toInt32(1), 1])) as res, toTypeName(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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af872f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af7b2d1 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af7c3f3 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d36920d 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000002d369e5f 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processOrdinaryQuery() @ 0x000000002d18af7b 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d17644a 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 15. asan_thread_start(void*) @ 0x000000000aa43059 16. ? @ 0x00007f35aab92ac3 17. ? @ 0x00007f35aac24850 2025.09.09 14:58:04.217295 [ 4025 ] {3826989e-9cdc-4b33-8132-a914a7ab6094} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=773, 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af872f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af7b2d1 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af7c3f3 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d36920d 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000002d369e5f 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processOrdinaryQuery() @ 0x000000002d18af7b 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d17644a 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 15. asan_thread_start(void*) @ 0x000000000aa43059 16. ? @ 0x00007f35aab92ac3 17. ? @ 0x00007f35aac24850 2025.09.09 14:58:04.696480 [ 2824 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:58:04.727146 [ 2830 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:58:05.001718 [ 4025 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 14:58:05.699294 [ 2841 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:58:05.729520 [ 2837 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:58:06.067975 [ 4025 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 14:58:06.702086 [ 2855 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:58:06.731950 [ 2856 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:58:07.082940 [ 4025 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 14:58:07.704933 [ 2888 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:58:07.735154 [ 2879 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:58:08.221748 [ 4025 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 14:58:08.707475 [ 2922 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:58:08.737709 [ 2912 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:58:09.323989 [ 13328 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 14:58:09.709993 [ 2929 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:58:09.740242 [ 2931 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:58:10.357520 [ 4023 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 14:58:10.712936 [ 2952 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:58:10.743278 [ 2962 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:58:11.383287 [ 4023 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 14:58:11.716501 [ 2981 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:58:11.746228 [ 2977 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:58:12.685658 [ 4023 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 14:58:12.719117 [ 3000 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:58:12.749132 [ 3004 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:58:13.721380 [ 3014 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:58:13.727117 [ 13328 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 14:58:13.752223 [ 3020 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:58:14.746614 [ 13328 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 14:58:14.747515 [ 3040 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:58:14.754725 [ 3041 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:58:15.277306 [ 3612 ] {} DynamicQueryHandler: Code: 452. DB::Exception: Setting max_execution_time shouldn't be greater than 60. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x0000000026f841fa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:368: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f81de0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/find_if.h:25: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f808a4 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000002d065739 10. ./build_docker/./src/Server/HTTPHandler.cpp:705: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000002d06d139 11. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000002d1cc337 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 15. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 16. asan_thread_start(void*) @ 0x000000000aa43059 17. ? @ 0x00007f35aab92ac3 18. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:58:15.723464 [ 13328 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 14:58:15.749633 [ 3063 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:58:15.757355 [ 3058 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:58:16.751742 [ 3088 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:58:16.759553 [ 3084 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:58:16.826387 [ 13328 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 14:58:17.754360 [ 3102 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:58:17.761561 [ 3099 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:58:17.818493 [ 13328 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 14:58:18.756813 [ 3129 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:58:18.763753 [ 3132 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:58:18.874143 [ 13328 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 14:58:19.759500 [ 3137 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:58:19.765996 [ 3152 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:58:19.863970 [ 13328 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 14:58:20.762069 [ 3175 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:58:20.768474 [ 3176 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:58:20.886326 [ 13328 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 14:58:21.764680 [ 3190 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:58:21.770774 [ 3194 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:58:21.821971 [ 13328 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 14:58:22.766958 [ 3208 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:58:22.773489 [ 3207 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:58:22.842616 [ 13328 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 14:58:23.769252 [ 3224 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:58:23.775714 [ 3226 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:58:23.865496 [ 13328 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 14:58:24.771462 [ 2753 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:58:24.777618 [ 2745 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:58:24.834757 [ 13328 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 14:58:25.773497 [ 2762 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:58:25.774334 [ 13328 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 14:58:25.779739 [ 2765 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:58:26.776227 [ 2777 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:58:26.782445 [ 2769 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:58:26.828307 [ 13328 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 14:58:26.922518 [ 3612 ] {} DynamicQueryHandler: Code: 452. DB::Exception: Setting max_execution_time shouldn't be greater than 60. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x0000000026f841fa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:368: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f81de0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/find_if.h:25: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f808a4 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000002d065739 10. ./build_docker/./src/Server/HTTPHandler.cpp:705: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000002d06d139 11. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000002d1cc337 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 15. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 16. asan_thread_start(void*) @ 0x000000000aa43059 17. ? @ 0x00007f35aab92ac3 18. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:58:27.784880 [ 2792 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:58:27.787548 [ 2793 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:58:27.864945 [ 13328 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 14:58:28.786837 [ 2801 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:58:28.789248 [ 13328 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 14:58:28.789481 [ 2809 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:58:29.751280 [ 13328 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 14:58:29.788961 [ 2823 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:58:29.791280 [ 2815 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:58:29.942576 [ 3337 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {cb913e3a-f414-4872-8c3b-02a3eff4ab8a::202509_1_55_11}: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=13, 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af80b71 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80746 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002c765aab 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:1197: ? @ 0x000000002c7602b8 8. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x000000002c75fc2b 9. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:0: DB::MergeTreeReaderCompact::MergeTreeReaderCompact(std::shared_ptr, DB::NamesAndTypesList, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*, DB::MarkCache*, DB::MarkRanges, DB::MergeTreeReaderSettings, std::map, std::allocator>>, std::function const&, int) @ 0x000000002c7aee03 10. ./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.h:16: DB::MergeTreeReaderCompactSingleBuffer::MergeTreeReaderCompactSingleBuffer&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int&&) @ 0x000000002c5d6d21 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::MergeTreeDataPartCompact::getReader(DB::NamesAndTypesList const&, std::shared_ptr const&, DB::MarkRanges const&, std::unordered_map, std::equal_to, std::allocator>> const&, DB::UncompressedCache*, DB::MarkCache*, std::shared_ptr const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) const @ 0x000000002c5d1037 12. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:169: DB::MergeTreeSequentialSource::MergeTreeSequentialSource(DB::MergeTreeSequentialSourceType, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::vector>, std::optional, bool, bool, bool) @ 0x000000002c80c330 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:35: DB::MergeTreeSequentialSource* std::construct_at[abi:v15007] const&, std::shared_ptr&, std::shared_ptr&, std::vector>&, std::optional, bool, bool&, bool&, DB::MergeTreeSequentialSource*>(DB::MergeTreeSequentialSource*, DB::MergeTreeSequentialSourceType&, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr&, std::shared_ptr&, std::vector>&, std::optional&&, bool&&, bool&, bool&) @ 0x000000002c81320f 14. ./contrib/llvm-project/libcxx/include/__memory/allocator_traits.h:298: DB::createMergeTreeSequentialSource(DB::MergeTreeSequentialSourceType, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::vector>, std::optional, std::shared_ptr>, bool, bool, bool) @ 0x000000002c810812 15. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1136: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::createMergedStream() @ 0x000000002c3dd079 16. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() @ 0x000000002c3d6516 17. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:534: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x000000002c3e2799 18. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::execute() @ 0x000000002c3ef3fe 19. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:0: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000002cc2f4c0 20. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000002c427f28 21. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000002c429675 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7eaf0 23. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001af8a79f 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 26. asan_thread_start(void*) @ 0x000000000aa43059 27. ? @ 0x00007f35aab92ac3 28. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:58:30.756172 [ 13328 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 14:58:30.791257 [ 2853 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:58:30.793079 [ 2858 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:58:31.793302 [ 2877 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:58:31.795198 [ 2874 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:58:31.876678 [ 13328 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 14:58:32.796239 [ 2882 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:58:32.797622 [ 2883 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:58:32.992099 [ 13328 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 14:58:33.798895 [ 2912 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:58:33.800262 [ 2904 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:58:33.956751 [ 13328 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 14:58:34.801549 [ 2913 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:58:34.802658 [ 2925 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:58:34.998114 [ 13328 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 14:58:35.803715 [ 2937 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:58:35.805015 [ 2938 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:58:35.942047 [ 13328 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 14:58:36.263511 [ 4023 ] {0e8e1d6c-dcf4-4b1f-b730-151fe6ec04ae} 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.10505.altinitytest (altinity build)) (from [::1]:60404) (comment: 01894_jit_aggregation_function_max_long.sql) (in query: SELECT id, max(value1), max(value2), max(value3) FROM test_table_null_specifics 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af819ed 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80746 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d34b5ca 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000002d3486e4 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000002d34827b 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002d36bcf7 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 12. asan_thread_start(void*) @ 0x000000000aa43059 13. ? @ 0x00007f35aab92ac3 14. ? @ 0x00007f35aac24850 2025.09.09 14:58:36.266863 [ 4023 ] {0e8e1d6c-dcf4-4b1f-b730-151fe6ec04ae} 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af819ed 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80746 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d34b5ca 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000002d3486e4 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000002d34827b 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002d36bcf7 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 12. asan_thread_start(void*) @ 0x000000000aa43059 13. ? @ 0x00007f35aab92ac3 14. ? @ 0x00007f35aac24850 2025.09.09 14:58:36.805980 [ 2949 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:58:36.807085 [ 2951 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:58:36.881690 [ 13328 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 14:58:37.807945 [ 2966 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:58:37.809050 [ 2967 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:58:37.969407 [ 13328 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 14:58:38.809800 [ 2977 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:58:38.810869 [ 2988 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:58:38.929210 [ 13328 ] {543b2b83-8976-4405-9f4e-ef2f278131c2} executeQuery: Code: 57. DB::Exception: Table test_3.test already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:43224) (comment: 02941_variant_type_2.sh) (in query: create table test (id UInt64, v Variant(String, UInt64, LowCardinality(String), Tuple(a UInt32, b UInt32), Array(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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa91e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1558: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291bc5ff 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291ac835 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000291c3415 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b382fc 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 15. asan_thread_start(void*) @ 0x000000000aa43059 16. ? @ 0x00007f35aab92ac3 17. ? @ 0x00007f35aac24850 2025.09.09 14:58:38.933275 [ 13328 ] {543b2b83-8976-4405-9f4e-ef2f278131c2} TCPHandler: Code: 57. DB::Exception: Table test_3.test already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa91e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1558: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291bc5ff 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291ac835 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000291c3415 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b382fc 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 15. asan_thread_start(void*) @ 0x000000000aa43059 16. ? @ 0x00007f35aab92ac3 17. ? @ 0x00007f35aac24850 2025.09.09 14:58:38.982858 [ 4023 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 14:58:39.590590 [ 13328 ] {2118aa8b-4c10-4b0d-bfb9-634304a75fde} executeQuery: Code: 44. DB::Exception: Object(max_dynamic_paths=2, max_dynamic_types=32, a.b.c UInt32) cannot be inside Nullable column. (ILLEGAL_COLUMN) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:43232) (comment: 02941_variant_type_2.sh) (in query: insert into test select number, NULL 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000aad4b34 4. ./build_docker/./src/Columns/ColumnNullable.cpp:37: DB::ColumnNullable::ColumnNullable(COW::mutable_ptr&&, COW::mutable_ptr&&) @ 0x000000002ae90228 5. DB::ColumnNullable::create(COW::immutable_ptr const&, COW::immutable_ptr const&) @ 0x000000000aaeba0c 6. ./build_docker/./src/Columns/ColumnNullable.cpp:0: DB::makeNullableOrLowCardinalityNullable(COW::immutable_ptr const&) @ 0x000000002aea27cf 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::buildInsertSelectPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x00000000293551b1 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:789: DB::InterpreterInsertQuery::execute() @ 0x000000002935b5a0 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b382fc 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 14:58:39.619411 [ 13328 ] {2118aa8b-4c10-4b0d-bfb9-634304a75fde} TCPHandler: Code: 44. DB::Exception: Object(max_dynamic_paths=2, max_dynamic_types=32, a.b.c UInt32) cannot be inside Nullable column. (ILLEGAL_COLUMN), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000aad4b34 4. ./build_docker/./src/Columns/ColumnNullable.cpp:37: DB::ColumnNullable::ColumnNullable(COW::mutable_ptr&&, COW::mutable_ptr&&) @ 0x000000002ae90228 5. DB::ColumnNullable::create(COW::immutable_ptr const&, COW::immutable_ptr const&) @ 0x000000000aaeba0c 6. ./build_docker/./src/Columns/ColumnNullable.cpp:0: DB::makeNullableOrLowCardinalityNullable(COW::immutable_ptr const&) @ 0x000000002aea27cf 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::buildInsertSelectPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x00000000293551b1 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:789: DB::InterpreterInsertQuery::execute() @ 0x000000002935b5a0 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b382fc 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 14:58:39.811730 [ 3000 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:58:39.812878 [ 3004 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:58:39.931185 [ 13328 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 14:58:40.154227 [ 13328 ] {9ccec853-a1dd-43b5-a254-547561501800} executeQuery: Code: 47. DB::Exception: Unknown expression identifier 'v' in scope SELECT v FROM test. (UNKNOWN_IDENTIFIER) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:43250) (comment: 02941_variant_type_2.sh) (in query: select v from test format Null;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String const&, String&&, String&&) @ 0x00000000283c6735 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3684: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002836a1d4 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028366290 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283b62c9 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002835ae03 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000028359104 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000028357f0d 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002921bdcc 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&) @ 0x000000002941f313 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&) @ 0x0000000029419aef 13. ./contrib/llvm-project/libcxx/include/vector:432: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000029421f5d 14. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000029344c1b 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*) @ 0x0000000029b3703b 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 18. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 22. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 14:58:40.157599 [ 13328 ] {9ccec853-a1dd-43b5-a254-547561501800} TCPHandler: Code: 47. DB::Exception: Unknown expression identifier 'v' in scope SELECT v FROM test. (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String const&, String&&, String&&) @ 0x00000000283c6735 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3684: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002836a1d4 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028366290 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283b62c9 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002835ae03 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000028359104 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000028357f0d 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002921bdcc 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&) @ 0x000000002941f313 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&) @ 0x0000000029419aef 13. ./contrib/llvm-project/libcxx/include/vector:432: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000029421f5d 14. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000029344c1b 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*) @ 0x0000000029b3703b 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 18. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 22. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 14:58:40.814014 [ 3024 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:58:40.815107 [ 3017 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:58:40.900772 [ 4023 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 14:58:41.816444 [ 3035 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:58:41.817018 [ 3031 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:58:41.900791 [ 13328 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 14:58:42.147540 [ 13328 ] {d9007749-4811-4aaf-bb6e-7f544f71ff59} executeQuery: Code: 57. DB::Exception: Table test_3.test already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:43292) (comment: 02941_variant_type_2.sh) (in query: CREATE TABLE test (`id` UInt64, `v` Variant(String, UInt64, LowCardinality(String), Tuple(a UInt32, b UInt32), Array(UInt64))) ENGINE = MergeTree ORDER BY id SETTINGS min_rows_for_wide_part = 100000000, min_bytes_for_wide_part = 1000000000, index_granularity_bytes = 10485760, index_granularity = 8192, ratio_of_defaults_for_sparse_serialization = 0.2957049310207367, replace_long_file_name_to_hash = false, max_file_name_length = 31, min_bytes_for_full_part_storage = 536870912, compact_parts_max_bytes_to_buffer = 380241953, compact_parts_max_granules_to_buffer = 239, compact_parts_merge_max_bytes_to_prefetch_part = 20257682, merge_max_block_size = 18681, old_parts_lifetime = 427., prefer_fetch_merged_part_size_threshold = 1, vertical_merge_algorithm_min_rows_to_activate = 851948, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 1, concurrent_part_removal_threshold = 100, allow_vertical_merges_from_compact_to_wide_parts = true, cache_populated_by_fetch = false, marks_compress_block_size = 9345, primary_key_compress_block_size = 20703), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa91e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1558: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291bc5ff 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291ac835 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000291c3415 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b382fc 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 15. asan_thread_start(void*) @ 0x000000000aa43059 16. ? @ 0x00007f35aab92ac3 17. ? @ 0x00007f35aac24850 2025.09.09 14:58:42.155654 [ 13328 ] {d9007749-4811-4aaf-bb6e-7f544f71ff59} TCPHandler: Code: 57. DB::Exception: Table test_3.test already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa91e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1558: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291bc5ff 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291ac835 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000291c3415 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b382fc 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 15. asan_thread_start(void*) @ 0x000000000aa43059 16. ? @ 0x00007f35aab92ac3 17. ? @ 0x00007f35aac24850 2025.09.09 14:58:42.818609 [ 3047 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:58:42.823753 [ 13328 ] {5a435bd7-7dfe-4e45-b695-1a443993fbbe} executeQuery: Code: 44. DB::Exception: Object(max_dynamic_paths=2, max_dynamic_types=32, a.b.c UInt32) cannot be inside Nullable column. (ILLEGAL_COLUMN) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:43300) (comment: 02941_variant_type_2.sh) (in query: insert into test select number, NULL 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000aad4b34 4. ./build_docker/./src/Columns/ColumnNullable.cpp:37: DB::ColumnNullable::ColumnNullable(COW::mutable_ptr&&, COW::mutable_ptr&&) @ 0x000000002ae90228 5. DB::ColumnNullable::create(COW::immutable_ptr const&, COW::immutable_ptr const&) @ 0x000000000aaeba0c 6. ./build_docker/./src/Columns/ColumnNullable.cpp:0: DB::makeNullableOrLowCardinalityNullable(COW::immutable_ptr const&) @ 0x000000002aea27cf 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::buildInsertSelectPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x00000000293551b1 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:789: DB::InterpreterInsertQuery::execute() @ 0x000000002935b5a0 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b382fc 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 14:58:42.827444 [ 13328 ] {5a435bd7-7dfe-4e45-b695-1a443993fbbe} TCPHandler: Code: 44. DB::Exception: Object(max_dynamic_paths=2, max_dynamic_types=32, a.b.c UInt32) cannot be inside Nullable column. (ILLEGAL_COLUMN), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000aad4b34 4. ./build_docker/./src/Columns/ColumnNullable.cpp:37: DB::ColumnNullable::ColumnNullable(COW::mutable_ptr&&, COW::mutable_ptr&&) @ 0x000000002ae90228 5. DB::ColumnNullable::create(COW::immutable_ptr const&, COW::immutable_ptr const&) @ 0x000000000aaeba0c 6. ./build_docker/./src/Columns/ColumnNullable.cpp:0: DB::makeNullableOrLowCardinalityNullable(COW::immutable_ptr const&) @ 0x000000002aea27cf 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::buildInsertSelectPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x00000000293551b1 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:789: DB::InterpreterInsertQuery::execute() @ 0x000000002935b5a0 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b382fc 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 14:58:42.876192 [ 3054 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:58:42.886586 [ 4023 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 14:58:43.354365 [ 13328 ] {a3947e20-5da1-4674-b85f-0103f3e23fa5} executeQuery: Code: 47. DB::Exception: Unknown expression identifier 'v' in scope SELECT v FROM test. (UNKNOWN_IDENTIFIER) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:43320) (comment: 02941_variant_type_2.sh) (in query: select v from test format Null;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String const&, String&&, String&&) @ 0x00000000283c6735 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3684: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002836a1d4 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028366290 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283b62c9 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002835ae03 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000028359104 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000028357f0d 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002921bdcc 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&) @ 0x000000002941f313 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&) @ 0x0000000029419aef 13. ./contrib/llvm-project/libcxx/include/vector:432: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000029421f5d 14. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000029344c1b 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*) @ 0x0000000029b3703b 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 18. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 22. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 14:58:43.357373 [ 13328 ] {a3947e20-5da1-4674-b85f-0103f3e23fa5} TCPHandler: Code: 47. DB::Exception: Unknown expression identifier 'v' in scope SELECT v FROM test. (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String const&, String&&, String&&) @ 0x00000000283c6735 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3684: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002836a1d4 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028366290 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283b62c9 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002835ae03 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000028359104 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000028357f0d 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002921bdcc 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&) @ 0x000000002941f313 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&) @ 0x0000000029419aef 13. ./contrib/llvm-project/libcxx/include/vector:432: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000029421f5d 14. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000029344c1b 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*) @ 0x0000000029b3703b 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 18. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 22. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 14:58:43.820736 [ 3062 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:58:43.858880 [ 13328 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 14:58:43.878758 [ 3064 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:58:44.712999 [ 13328 ] {670a5641-9d91-4f61-9521-f8b936c80b8d} executeQuery: Code: 47. DB::Exception: Unknown expression identifier 'v' in scope SELECT v FROM test. (UNKNOWN_IDENTIFIER) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:43344) (comment: 02941_variant_type_2.sh) (in query: select v from test format Null;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String const&, String&&, String&&) @ 0x00000000283c6735 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3684: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002836a1d4 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028366290 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283b62c9 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002835ae03 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000028359104 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000028357f0d 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002921bdcc 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&) @ 0x000000002941f313 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&) @ 0x0000000029419aef 13. ./contrib/llvm-project/libcxx/include/vector:432: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000029421f5d 14. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000029344c1b 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*) @ 0x0000000029b3703b 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 18. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 22. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 14:58:44.731842 [ 13328 ] {670a5641-9d91-4f61-9521-f8b936c80b8d} TCPHandler: Code: 47. DB::Exception: Unknown expression identifier 'v' in scope SELECT v FROM test. (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String const&, String&&, String&&) @ 0x00000000283c6735 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3684: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002836a1d4 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028366290 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283b62c9 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002835ae03 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000028359104 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000028357f0d 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002921bdcc 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&) @ 0x000000002941f313 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&) @ 0x0000000029419aef 13. ./contrib/llvm-project/libcxx/include/vector:432: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000029421f5d 14. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000029344c1b 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*) @ 0x0000000029b3703b 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 18. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 22. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 14:58:44.822978 [ 3076 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:58:44.881168 [ 3079 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:58:44.978022 [ 13328 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 14:58:45.832050 [ 3083 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:58:45.883183 [ 3094 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:58:45.997892 [ 4023 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 14:58:46.472589 [ 13328 ] {8b1e3e40-1ff0-47d7-83fa-74cf2a044d62} executeQuery: Code: 57. DB::Exception: Table test_3.test already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:43396) (comment: 02941_variant_type_2.sh) (in query: CREATE TABLE test (`id` UInt64, `v` Variant(String, UInt64, LowCardinality(String), Tuple(a UInt32, b UInt32), Array(UInt64))) ENGINE = MergeTree ORDER BY id SETTINGS min_rows_for_wide_part = 1, min_bytes_for_wide_part = 1, index_granularity_bytes = 10485760, index_granularity = 8192, ratio_of_defaults_for_sparse_serialization = 0.2957049310207367, replace_long_file_name_to_hash = false, max_file_name_length = 31, min_bytes_for_full_part_storage = 536870912, compact_parts_max_bytes_to_buffer = 380241953, compact_parts_max_granules_to_buffer = 239, compact_parts_merge_max_bytes_to_prefetch_part = 20257682, merge_max_block_size = 18681, old_parts_lifetime = 427., prefer_fetch_merged_part_size_threshold = 1, vertical_merge_algorithm_min_rows_to_activate = 851948, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 1, concurrent_part_removal_threshold = 100, allow_vertical_merges_from_compact_to_wide_parts = true, cache_populated_by_fetch = false, marks_compress_block_size = 9345, primary_key_compress_block_size = 20703), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa91e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1558: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291bc5ff 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291ac835 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000291c3415 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b382fc 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 15. asan_thread_start(void*) @ 0x000000000aa43059 16. ? @ 0x00007f35aab92ac3 17. ? @ 0x00007f35aac24850 2025.09.09 14:58:46.530023 [ 13328 ] {8b1e3e40-1ff0-47d7-83fa-74cf2a044d62} TCPHandler: Code: 57. DB::Exception: Table test_3.test already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa91e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1558: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291bc5ff 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291ac835 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000291c3415 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b382fc 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 15. asan_thread_start(void*) @ 0x000000000aa43059 16. ? @ 0x00007f35aab92ac3 17. ? @ 0x00007f35aac24850 2025.09.09 14:58:46.835011 [ 3111 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:58:46.885246 [ 3112 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:58:46.995914 [ 13328 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 14:58:47.317998 [ 13328 ] {46e71079-7760-4fd8-b4ee-4cda4c7f9c8a} executeQuery: Code: 44. DB::Exception: Object(max_dynamic_paths=2, max_dynamic_types=32, a.b.c UInt32) cannot be inside Nullable column. (ILLEGAL_COLUMN) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:43414) (comment: 02941_variant_type_2.sh) (in query: insert into test select number, NULL 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000aad4b34 4. ./build_docker/./src/Columns/ColumnNullable.cpp:37: DB::ColumnNullable::ColumnNullable(COW::mutable_ptr&&, COW::mutable_ptr&&) @ 0x000000002ae90228 5. DB::ColumnNullable::create(COW::immutable_ptr const&, COW::immutable_ptr const&) @ 0x000000000aaeba0c 6. ./build_docker/./src/Columns/ColumnNullable.cpp:0: DB::makeNullableOrLowCardinalityNullable(COW::immutable_ptr const&) @ 0x000000002aea27cf 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::buildInsertSelectPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x00000000293551b1 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:789: DB::InterpreterInsertQuery::execute() @ 0x000000002935b5a0 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b382fc 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 14:58:47.331918 [ 13328 ] {46e71079-7760-4fd8-b4ee-4cda4c7f9c8a} TCPHandler: Code: 44. DB::Exception: Object(max_dynamic_paths=2, max_dynamic_types=32, a.b.c UInt32) cannot be inside Nullable column. (ILLEGAL_COLUMN), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000aad4b34 4. ./build_docker/./src/Columns/ColumnNullable.cpp:37: DB::ColumnNullable::ColumnNullable(COW::mutable_ptr&&, COW::mutable_ptr&&) @ 0x000000002ae90228 5. DB::ColumnNullable::create(COW::immutable_ptr const&, COW::immutable_ptr const&) @ 0x000000000aaeba0c 6. ./build_docker/./src/Columns/ColumnNullable.cpp:0: DB::makeNullableOrLowCardinalityNullable(COW::immutable_ptr const&) @ 0x000000002aea27cf 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::buildInsertSelectPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x00000000293551b1 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:789: DB::InterpreterInsertQuery::execute() @ 0x000000002935b5a0 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b382fc 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 14:58:47.837304 [ 3132 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:58:47.887367 [ 3131 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:58:47.907783 [ 13328 ] {7ef51f12-d9af-4100-ab92-2001ba00903f} executeQuery: Code: 47. DB::Exception: Unknown expression identifier 'v' in scope SELECT v FROM test. (UNKNOWN_IDENTIFIER) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:43420) (comment: 02941_variant_type_2.sh) (in query: select v from test format Null;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String const&, String&&, String&&) @ 0x00000000283c6735 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3684: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002836a1d4 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028366290 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283b62c9 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002835ae03 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000028359104 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000028357f0d 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002921bdcc 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&) @ 0x000000002941f313 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&) @ 0x0000000029419aef 13. ./contrib/llvm-project/libcxx/include/vector:432: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000029421f5d 14. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000029344c1b 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*) @ 0x0000000029b3703b 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 18. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 22. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 14:58:47.916700 [ 13328 ] {7ef51f12-d9af-4100-ab92-2001ba00903f} TCPHandler: Code: 47. DB::Exception: Unknown expression identifier 'v' in scope SELECT v FROM test. (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String const&, String&&, String&&) @ 0x00000000283c6735 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3684: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002836a1d4 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028366290 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283b62c9 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002835ae03 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000028359104 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000028357f0d 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002921bdcc 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&) @ 0x000000002941f313 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&) @ 0x0000000029419aef 13. ./contrib/llvm-project/libcxx/include/vector:432: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000029421f5d 14. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000029344c1b 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*) @ 0x0000000029b3703b 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 18. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 22. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 14:58:47.932861 [ 4023 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 14:58:48.840353 [ 3140 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:58:48.889497 [ 3150 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:58:48.897219 [ 13328 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 14:58:48.993985 [ 4023 ] {d32465fc-4502-427d-92cc-d41ca044ca2e} executeQuery: Code: 47. DB::Exception: Unknown expression identifier 'v' in scope SELECT v FROM test. (UNKNOWN_IDENTIFIER) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:59894) (comment: 02941_variant_type_2.sh) (in query: select v from test format Null;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String const&, String&&, String&&) @ 0x00000000283c6735 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3684: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002836a1d4 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028366290 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283b62c9 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002835ae03 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000028359104 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000028357f0d 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002921bdcc 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&) @ 0x000000002941f313 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&) @ 0x0000000029419aef 13. ./contrib/llvm-project/libcxx/include/vector:432: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000029421f5d 14. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000029344c1b 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*) @ 0x0000000029b3703b 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 18. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 22. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 14:58:48.999562 [ 4023 ] {d32465fc-4502-427d-92cc-d41ca044ca2e} TCPHandler: Code: 47. DB::Exception: Unknown expression identifier 'v' in scope SELECT v FROM test. (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String const&, String&&, String&&) @ 0x00000000283c6735 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3684: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002836a1d4 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028366290 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283b62c9 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002835ae03 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000028359104 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000028357f0d 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002921bdcc 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&) @ 0x000000002941f313 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&) @ 0x0000000029419aef 13. ./contrib/llvm-project/libcxx/include/vector:432: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000029421f5d 14. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000029344c1b 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*) @ 0x0000000029b3703b 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 18. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 22. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 14:58:49.842460 [ 3161 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:58:49.886601 [ 13328 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 14:58:49.891312 [ 3163 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:58:50.833015 [ 4023 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 14:58:50.844330 [ 3175 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:58:50.893491 [ 3180 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:58:50.997521 [ 13328 ] {20582e4b-3e8a-43ed-8e63-34a0b07220cd} Context: Server has databases (for example `test_1603_rename_bug_ordinary`) with Ordinary engine, which was deprecated. To convert this database to the new Atomic engine, create a flag /var/lib/clickhouse/flags/convert_ordinary_to_atomic and make sure that ClickHouse has write permission for it. Example: sudo touch '/var/lib/clickhouse/flags/convert_ordinary_to_atomic' && sudo chmod 666 '/var/lib/clickhouse/flags/convert_ordinary_to_atomic' 2025.09.09 14:58:51.616269 [ 13328 ] {09f8b8ec-7d82-47f7-a1df-75acb8d484c3} executeQuery: Code: 57. DB::Exception: Table `test_1603_rename_bug_ordinary`.`foo` already exists (detached). (TABLE_ALREADY_EXISTS) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:59932) (comment: 01603_rename_overwrite_bug.sql) (in query: rename table test_1603_rename_bug_ordinary.bar to test_1603_rename_bug_ordinary.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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa91e9a 4. ./build_docker/./src/Databases/DatabaseOnDisk.cpp:393: DB::DatabaseOnDisk::checkMetadataFilenameAvailabilityUnlocked(String const&) const @ 0x0000000027cd2bd4 5. ./contrib/llvm-project/libcxx/include/__mutex_base:100: DB::DatabaseOnDisk::checkMetadataFilenameAvailability(String const&) const @ 0x0000000027cd2587 6. ./build_docker/./src/Databases/DatabaseOnDisk.cpp:464: DB::DatabaseOnDisk::renameTable(std::shared_ptr, String const&, DB::IDatabase&, String const&, bool, bool) @ 0x0000000027cd3c72 7. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:152: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x000000002936c971 8. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:0: DB::InterpreterRenameQuery::execute() @ 0x000000002936a33a 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b382fc 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 14:58:51.625557 [ 13328 ] {09f8b8ec-7d82-47f7-a1df-75acb8d484c3} TCPHandler: Code: 57. DB::Exception: Table `test_1603_rename_bug_ordinary`.`foo` already exists (detached). (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa91e9a 4. ./build_docker/./src/Databases/DatabaseOnDisk.cpp:393: DB::DatabaseOnDisk::checkMetadataFilenameAvailabilityUnlocked(String const&) const @ 0x0000000027cd2bd4 5. ./contrib/llvm-project/libcxx/include/__mutex_base:100: DB::DatabaseOnDisk::checkMetadataFilenameAvailability(String const&) const @ 0x0000000027cd2587 6. ./build_docker/./src/Databases/DatabaseOnDisk.cpp:464: DB::DatabaseOnDisk::renameTable(std::shared_ptr, String const&, DB::IDatabase&, String const&, bool, bool) @ 0x0000000027cd3c72 7. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:152: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x000000002936c971 8. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:0: DB::InterpreterRenameQuery::execute() @ 0x000000002936a33a 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b382fc 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 14:58:51.799563 [ 4023 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 14:58:51.846711 [ 3186 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:58:51.895481 [ 3189 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:58:52.150251 [ 13328 ] {92929edf-a2c7-45db-9da0-e3b009f77257} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:59932) (comment: 01603_rename_overwrite_bug.sql) (in query: DROP DATABASE test_1603_rename_bug_ordinary;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aac868e 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x00000000286b57c7 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x00000000291f5630 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:361: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000291edc97 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x00000000291ebf11 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x00000000291eb7ed 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b382fc 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 14:58:52.153258 [ 13328 ] {92929edf-a2c7-45db-9da0-e3b009f77257} TCPHandler: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aac868e 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x00000000286b57c7 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x00000000291f5630 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:361: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000291edc97 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x00000000291ebf11 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x00000000291eb7ed 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b382fc 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 14:58:52.809434 [ 4023 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 14:58:52.849200 [ 3200 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:58:52.898072 [ 3199 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:58:52.961394 [ 3328 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {44b09201-5a0e-4da3-91d1-ac60ea8508c5::202509_1_58_12}: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=13, jobs=0). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af80b71 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80746 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002c765aab 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:1197: ? @ 0x000000002c7602b8 8. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x000000002c75fc2b 9. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:0: DB::MergeTreeReaderCompact::MergeTreeReaderCompact(std::shared_ptr, DB::NamesAndTypesList, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*, DB::MarkCache*, DB::MarkRanges, DB::MergeTreeReaderSettings, std::map, std::allocator>>, std::function const&, int) @ 0x000000002c7aee03 10. ./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.h:16: DB::MergeTreeReaderCompactSingleBuffer::MergeTreeReaderCompactSingleBuffer&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int&&) @ 0x000000002c5d6d21 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::MergeTreeDataPartCompact::getReader(DB::NamesAndTypesList const&, std::shared_ptr const&, DB::MarkRanges const&, std::unordered_map, std::equal_to, std::allocator>> const&, DB::UncompressedCache*, DB::MarkCache*, std::shared_ptr const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) const @ 0x000000002c5d1037 12. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:169: DB::MergeTreeSequentialSource::MergeTreeSequentialSource(DB::MergeTreeSequentialSourceType, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::vector>, std::optional, bool, bool, bool) @ 0x000000002c80c330 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:35: DB::MergeTreeSequentialSource* std::construct_at[abi:v15007] const&, std::shared_ptr&, std::shared_ptr&, std::vector>&, std::optional, bool, bool&, bool&, DB::MergeTreeSequentialSource*>(DB::MergeTreeSequentialSource*, DB::MergeTreeSequentialSourceType&, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr&, std::shared_ptr&, std::vector>&, std::optional&&, bool&&, bool&, bool&) @ 0x000000002c81320f 14. ./contrib/llvm-project/libcxx/include/__memory/allocator_traits.h:298: DB::createMergeTreeSequentialSource(DB::MergeTreeSequentialSourceType, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::vector>, std::optional, std::shared_ptr>, bool, bool, bool) @ 0x000000002c810812 15. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1136: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::createMergedStream() @ 0x000000002c3dd079 16. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() @ 0x000000002c3d6516 17. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:534: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x000000002c3e2799 18. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::execute() @ 0x000000002c3ef3fe 19. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:0: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000002cc2f4c0 20. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000002c427f28 21. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000002c429675 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7eaf0 23. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001af8a79f 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 26. asan_thread_start(void*) @ 0x000000000aa43059 27. ? @ 0x00007f35aab92ac3 28. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:58:53.836956 [ 13328 ] {2278dfde-9320-4956-94bc-34098873d496} executeQuery: Code: 57. DB::Exception: Table `test_1603_rename_bug_ordinary`.`foo` already exists (detached). (TABLE_ALREADY_EXISTS) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:59954) (comment: 01603_rename_overwrite_bug.sql) (in query: rename table test_1603_rename_bug_ordinary.bar to test_1603_rename_bug_ordinary.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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa91e9a 4. ./build_docker/./src/Databases/DatabaseOnDisk.cpp:393: DB::DatabaseOnDisk::checkMetadataFilenameAvailabilityUnlocked(String const&) const @ 0x0000000027cd2bd4 5. ./contrib/llvm-project/libcxx/include/__mutex_base:100: DB::DatabaseOnDisk::checkMetadataFilenameAvailability(String const&) const @ 0x0000000027cd2587 6. ./build_docker/./src/Databases/DatabaseOnDisk.cpp:464: DB::DatabaseOnDisk::renameTable(std::shared_ptr, String const&, DB::IDatabase&, String const&, bool, bool) @ 0x0000000027cd3c72 7. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:152: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x000000002936c971 8. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:0: DB::InterpreterRenameQuery::execute() @ 0x000000002936a33a 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b382fc 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 14:58:53.839955 [ 13328 ] {2278dfde-9320-4956-94bc-34098873d496} TCPHandler: Code: 57. DB::Exception: Table `test_1603_rename_bug_ordinary`.`foo` already exists (detached). (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa91e9a 4. ./build_docker/./src/Databases/DatabaseOnDisk.cpp:393: DB::DatabaseOnDisk::checkMetadataFilenameAvailabilityUnlocked(String const&) const @ 0x0000000027cd2bd4 5. ./contrib/llvm-project/libcxx/include/__mutex_base:100: DB::DatabaseOnDisk::checkMetadataFilenameAvailability(String const&) const @ 0x0000000027cd2587 6. ./build_docker/./src/Databases/DatabaseOnDisk.cpp:464: DB::DatabaseOnDisk::renameTable(std::shared_ptr, String const&, DB::IDatabase&, String const&, bool, bool) @ 0x0000000027cd3c72 7. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:152: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x000000002936c971 8. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:0: DB::InterpreterRenameQuery::execute() @ 0x000000002936a33a 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b382fc 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 14:58:53.840661 [ 4023 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 14:58:53.851371 [ 3223 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:58:53.901235 [ 3217 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:58:54.367809 [ 13328 ] {cc6fac4c-1166-4ab7-a19a-ef985f89136c} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:59954) (comment: 01603_rename_overwrite_bug.sql) (in query: DROP DATABASE test_1603_rename_bug_ordinary;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aac868e 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x00000000286b57c7 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x00000000291f5630 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:361: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000291edc97 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x00000000291ebf11 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x00000000291eb7ed 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b382fc 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 14:58:54.376308 [ 13328 ] {cc6fac4c-1166-4ab7-a19a-ef985f89136c} TCPHandler: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aac868e 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x00000000286b57c7 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x00000000291f5630 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:361: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000291edc97 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x00000000291ebf11 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x00000000291eb7ed 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b382fc 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 14:58:54.853800 [ 3240 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:58:54.888611 [ 13328 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 14:58:54.903745 [ 3239 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:58:55.141943 [ 13328 ] {857555a0-33fd-4a5a-a0dc-341d76ac3dc8} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:59976) (comment: 01603_rename_overwrite_bug.sql) (in query: DROP database IF EXISTS test_1603_rename_bug_ordinary;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aac868e 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x00000000286b57c7 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x00000000291f5630 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:361: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000291edc97 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x00000000291ebf11 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x00000000291eb7ed 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b382fc 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 14:58:55.143635 [ 13328 ] {857555a0-33fd-4a5a-a0dc-341d76ac3dc8} TCPHandler: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aac868e 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x00000000286b57c7 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x00000000291f5630 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:361: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000291edc97 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x00000000291ebf11 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x00000000291eb7ed 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b382fc 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 14:58:55.857072 [ 2746 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:58:55.909248 [ 2756 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:58:55.910924 [ 4023 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 14:58:56.771098 [ 13328 ] {83576ada-eb4d-4c18-bf01-8cb33fe20707} executeQuery: Code: 57. DB::Exception: Table `test_1603_rename_bug_ordinary`.`foo` already exists (detached). (TABLE_ALREADY_EXISTS) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:59982) (comment: 01603_rename_overwrite_bug.sql) (in query: rename table test_1603_rename_bug_ordinary.bar to test_1603_rename_bug_ordinary.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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa91e9a 4. ./build_docker/./src/Databases/DatabaseOnDisk.cpp:393: DB::DatabaseOnDisk::checkMetadataFilenameAvailabilityUnlocked(String const&) const @ 0x0000000027cd2bd4 5. ./contrib/llvm-project/libcxx/include/__mutex_base:100: DB::DatabaseOnDisk::checkMetadataFilenameAvailability(String const&) const @ 0x0000000027cd2587 6. ./build_docker/./src/Databases/DatabaseOnDisk.cpp:464: DB::DatabaseOnDisk::renameTable(std::shared_ptr, String const&, DB::IDatabase&, String const&, bool, bool) @ 0x0000000027cd3c72 7. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:152: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x000000002936c971 8. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:0: DB::InterpreterRenameQuery::execute() @ 0x000000002936a33a 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b382fc 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 14:58:56.773516 [ 13328 ] {83576ada-eb4d-4c18-bf01-8cb33fe20707} TCPHandler: Code: 57. DB::Exception: Table `test_1603_rename_bug_ordinary`.`foo` already exists (detached). (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa91e9a 4. ./build_docker/./src/Databases/DatabaseOnDisk.cpp:393: DB::DatabaseOnDisk::checkMetadataFilenameAvailabilityUnlocked(String const&) const @ 0x0000000027cd2bd4 5. ./contrib/llvm-project/libcxx/include/__mutex_base:100: DB::DatabaseOnDisk::checkMetadataFilenameAvailability(String const&) const @ 0x0000000027cd2587 6. ./build_docker/./src/Databases/DatabaseOnDisk.cpp:464: DB::DatabaseOnDisk::renameTable(std::shared_ptr, String const&, DB::IDatabase&, String const&, bool, bool) @ 0x0000000027cd3c72 7. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:152: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x000000002936c971 8. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:0: DB::InterpreterRenameQuery::execute() @ 0x000000002936a33a 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b382fc 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 14:58:56.859551 [ 2755 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:58:56.911821 [ 2771 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:58:57.015328 [ 4023 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 14:58:57.862121 [ 2777 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:58:57.914055 [ 2774 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:58:58.021487 [ 13328 ] {38d05345-df74-4daf-98d0-e97afa3f09a9} executeQuery: Code: 57. DB::Exception: Table `test_1603_rename_bug_atomic`.`foo` already exists (detached). (TABLE_ALREADY_EXISTS) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:59982) (comment: 01603_rename_overwrite_bug.sql) (in query: rename table test_1603_rename_bug_atomic.bar to test_1603_rename_bug_atomic.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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa91e9a 4. ./build_docker/./src/Databases/DatabaseOnDisk.cpp:393: DB::DatabaseOnDisk::checkMetadataFilenameAvailabilityUnlocked(String const&) const @ 0x0000000027cd2bd4 5. ./build_docker/./src/Databases/DatabaseAtomic.cpp:0: DB::DatabaseAtomic::renameTable(std::shared_ptr, String const&, DB::IDatabase&, String const&, bool, bool) @ 0x0000000027cf65b5 6. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:152: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x000000002936c971 7. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:0: DB::InterpreterRenameQuery::execute() @ 0x000000002936a33a 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b382fc 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 11. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 15. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 16. asan_thread_start(void*) @ 0x000000000aa43059 17. ? @ 0x00007f35aab92ac3 18. ? @ 0x00007f35aac24850 2025.09.09 14:58:58.024457 [ 13328 ] {38d05345-df74-4daf-98d0-e97afa3f09a9} TCPHandler: Code: 57. DB::Exception: Table `test_1603_rename_bug_atomic`.`foo` already exists (detached). (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa91e9a 4. ./build_docker/./src/Databases/DatabaseOnDisk.cpp:393: DB::DatabaseOnDisk::checkMetadataFilenameAvailabilityUnlocked(String const&) const @ 0x0000000027cd2bd4 5. ./build_docker/./src/Databases/DatabaseAtomic.cpp:0: DB::DatabaseAtomic::renameTable(std::shared_ptr, String const&, DB::IDatabase&, String const&, bool, bool) @ 0x0000000027cf65b5 6. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:152: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x000000002936c971 7. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:0: DB::InterpreterRenameQuery::execute() @ 0x000000002936a33a 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b382fc 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 11. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 15. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 16. asan_thread_start(void*) @ 0x000000000aa43059 17. ? @ 0x00007f35aab92ac3 18. ? @ 0x00007f35aac24850 2025.09.09 14:58:58.041763 [ 4023 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 14:58:58.864753 [ 2797 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:58:58.916473 [ 2796 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:58:59.050893 [ 13328 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 14:58:59.867397 [ 2805 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:58:59.919917 [ 2816 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:59:00.071486 [ 13328 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 14:59:00.869747 [ 2834 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:59:00.922341 [ 2827 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:59:01.098955 [ 13328 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 14:59:01.911379 [ 2844 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:59:01.924816 [ 2851 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:59:02.123439 [ 13328 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 14:59:02.913780 [ 2864 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:59:02.927703 [ 2862 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:59:03.184957 [ 4023 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 14:59:03.916393 [ 2880 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:59:03.930068 [ 2884 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:59:04.282648 [ 4023 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 14:59:04.919719 [ 2890 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:59:04.933228 [ 2900 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:59:05.244294 [ 13328 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 14:59:05.376600 [ 3612 ] {} DynamicQueryHandler: Code: 452. DB::Exception: Setting max_execution_time shouldn't be greater than 60. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x0000000026f841fa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:368: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f81de0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/find_if.h:25: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f808a4 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000002d065739 10. ./build_docker/./src/Server/HTTPHandler.cpp:705: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000002d06d139 11. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000002d1cc337 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 15. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 16. asan_thread_start(void*) @ 0x000000000aa43059 17. ? @ 0x00007f35aab92ac3 18. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:59:05.922076 [ 2905 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:59:05.935959 [ 2910 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:59:06.202307 [ 13328 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 14:59:06.924886 [ 2923 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:59:06.938987 [ 2930 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:59:07.249141 [ 13328 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 14:59:07.927495 [ 2938 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:59:07.941176 [ 2939 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:59:08.220636 [ 13328 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 14:59:08.930116 [ 2947 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:59:08.943346 [ 2954 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:59:09.193684 [ 13328 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 14:59:09.932692 [ 2964 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:59:09.945481 [ 2968 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:59:10.088148 [ 13328 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 14:59:10.935147 [ 2977 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:59:10.947828 [ 2988 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:59:11.124373 [ 13328 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 14:59:11.939480 [ 2987 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:59:11.949938 [ 2999 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:59:12.144998 [ 13328 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 14:59:12.941875 [ 3016 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:59:12.952181 [ 3021 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:59:13.187037 [ 13328 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 14:59:13.944316 [ 3023 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:59:13.955114 [ 3027 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:59:14.164199 [ 13328 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 14:59:14.946527 [ 3041 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:59:14.957302 [ 3042 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:59:15.115445 [ 13328 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 14:59:15.948817 [ 3057 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:59:15.959596 [ 3062 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:59:16.063203 [ 13328 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 14:59:16.951114 [ 3078 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:59:16.965805 [ 3082 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:59:17.123628 [ 13328 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 14:59:17.986398 [ 3098 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:59:17.986545 [ 3097 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:59:18.180503 [ 13328 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 14:59:18.989524 [ 3117 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:59:18.990402 [ 3116 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:59:19.348506 [ 13328 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 14:59:19.991966 [ 3123 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:59:19.992950 [ 3129 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:59:20.387838 [ 13328 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 14:59:20.994484 [ 3150 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:59:20.995188 [ 3146 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:59:21.372425 [ 13328 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 14:59:21.996704 [ 3153 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:59:21.997327 [ 3161 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:59:22.337001 [ 13328 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 14:59:22.999056 [ 3176 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:59:23.006551 [ 3178 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:59:23.261800 [ 13328 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 14:59:24.001681 [ 3192 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:59:24.009129 [ 3191 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:59:24.178368 [ 13328 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 14:59:25.004439 [ 3209 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:59:25.011009 [ 3214 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:59:25.148529 [ 13328 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 14:59:26.006569 [ 3233 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:59:26.012973 [ 3225 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:59:26.084482 [ 13328 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 14:59:27.008507 [ 3241 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:59:27.015210 [ 3239 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:59:27.080408 [ 13328 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 14:59:27.783277 [ 4023 ] {9eb7f343-e830-4f5c-b86b-c9ec602e3e13} executeQuery: Code: 53. DB::Exception: Cannot convert string 'a' to type UInt8. (TYPE_MISMATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:52976) (comment: 01017_in_unconvertible_complex_type.sql) (in query: -- When left and right element types are not compatible, we should get an error. select (toUInt8(1)) in ('a');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&, String&&) @ 0x000000000e9e161a 4. ./build_docker/./src/Interpreters/convertFieldToType.cpp:559: DB::(anonymous namespace)::convertFieldToTypeImpl(DB::Field const&, DB::IDataType const&, DB::IDataType const*) @ 0x0000000029aa854f 5. ./build_docker/./src/Interpreters/convertFieldToType.cpp:611: DB::convertFieldToType(DB::Field const&, DB::IDataType const&, DB::IDataType const*) @ 0x0000000029aa2141 6. ./src/Core/Field.h:455: DB::convertFieldToTypeStrict(DB::Field const&, DB::IDataType const&, DB::IDataType const&) @ 0x0000000029aa956b 7. ./contrib/llvm-project/libcxx/include/optional:344: DB::Block DB::(anonymous namespace)::createBlockFromCollection(DB::Array const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, bool) @ 0x0000000028450a80 8. ./contrib/llvm-project/libcxx/include/vector:961: DB::getSetElementsForConstantValue(std::shared_ptr const&, DB::Field const&, std::shared_ptr const&, bool) @ 0x000000002844dd89 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3398: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283990cb 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000028367bce 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028366290 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283b62c9 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002835ae03 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000028359104 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000028357f0d 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002921bdcc 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&) @ 0x000000002941f313 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&) @ 0x0000000029419aef 19. ./contrib/llvm-project/libcxx/include/vector:432: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000029421f5d 20. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000029344c1b 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*) @ 0x0000000029b3703b 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 23. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 24. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 29. asan_thread_start(void*) @ 0x000000000aa43059 30. ? @ 0x00007f35aab92ac3 31. ? @ 0x00007f35aac24850 2025.09.09 14:59:27.786988 [ 4023 ] {9eb7f343-e830-4f5c-b86b-c9ec602e3e13} TCPHandler: Code: 53. DB::Exception: Cannot convert string 'a' to type UInt8. (TYPE_MISMATCH), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&, String&&) @ 0x000000000e9e161a 4. ./build_docker/./src/Interpreters/convertFieldToType.cpp:559: DB::(anonymous namespace)::convertFieldToTypeImpl(DB::Field const&, DB::IDataType const&, DB::IDataType const*) @ 0x0000000029aa854f 5. ./build_docker/./src/Interpreters/convertFieldToType.cpp:611: DB::convertFieldToType(DB::Field const&, DB::IDataType const&, DB::IDataType const*) @ 0x0000000029aa2141 6. ./src/Core/Field.h:455: DB::convertFieldToTypeStrict(DB::Field const&, DB::IDataType const&, DB::IDataType const&) @ 0x0000000029aa956b 7. ./contrib/llvm-project/libcxx/include/optional:344: DB::Block DB::(anonymous namespace)::createBlockFromCollection(DB::Array const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, bool) @ 0x0000000028450a80 8. ./contrib/llvm-project/libcxx/include/vector:961: DB::getSetElementsForConstantValue(std::shared_ptr const&, DB::Field const&, std::shared_ptr const&, bool) @ 0x000000002844dd89 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3398: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283990cb 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000028367bce 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028366290 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283b62c9 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002835ae03 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000028359104 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000028357f0d 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002921bdcc 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&) @ 0x000000002941f313 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&) @ 0x0000000029419aef 19. ./contrib/llvm-project/libcxx/include/vector:432: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000029421f5d 20. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000029344c1b 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*) @ 0x0000000029b3703b 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 23. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 24. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 29. asan_thread_start(void*) @ 0x000000000aa43059 30. ? @ 0x00007f35aab92ac3 31. ? @ 0x00007f35aac24850 2025.09.09 14:59:27.946045 [ 4023 ] {12593250-ebd2-423f-ae98-44fa45b3b5c7} executeQuery: Code: 53. DB::Exception: Cannot convert string 'a' to type UInt8. (TYPE_MISMATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:52976) (comment: 01017_in_unconvertible_complex_type.sql) (in query: select [toUInt8(1)] in ['a'];), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&, String&&) @ 0x000000000e9e161a 4. ./build_docker/./src/Interpreters/convertFieldToType.cpp:559: DB::(anonymous namespace)::convertFieldToTypeImpl(DB::Field const&, DB::IDataType const&, DB::IDataType const*) @ 0x0000000029aa854f 5. ./build_docker/./src/Interpreters/convertFieldToType.cpp:611: DB::convertFieldToType(DB::Field const&, DB::IDataType const&, DB::IDataType const*) @ 0x0000000029aa2141 6. ./build_docker/./src/Interpreters/convertFieldToType.cpp:0: DB::(anonymous namespace)::convertFieldToTypeImpl(DB::Field const&, DB::IDataType const&, DB::IDataType const*) @ 0x0000000029aa3e34 7. ./build_docker/./src/Interpreters/convertFieldToType.cpp:611: DB::convertFieldToType(DB::Field const&, DB::IDataType const&, DB::IDataType const*) @ 0x0000000029aa2141 8. ./src/Core/Field.h:455: DB::convertFieldToTypeStrict(DB::Field const&, DB::IDataType const&, DB::IDataType const&) @ 0x0000000029aa956b 9. ./contrib/llvm-project/libcxx/include/optional:344: DB::Block DB::(anonymous namespace)::createBlockFromCollection(DB::Array const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, bool) @ 0x0000000028450a80 10. ./contrib/llvm-project/libcxx/include/vector:961: DB::getSetElementsForConstantValue(std::shared_ptr const&, DB::Field const&, std::shared_ptr const&, bool) @ 0x000000002844dd89 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3398: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283990cb 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000028367bce 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028366290 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283b62c9 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002835ae03 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000028359104 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000028357f0d 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002921bdcc 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&) @ 0x000000002941f313 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&) @ 0x0000000029419aef 21. ./contrib/llvm-project/libcxx/include/vector:432: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000029421f5d 22. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000029344c1b 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*) @ 0x0000000029b3703b 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 25. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 26. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 30. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 31. asan_thread_start(void*) @ 0x000000000aa43059 2025.09.09 14:59:27.962227 [ 4023 ] {12593250-ebd2-423f-ae98-44fa45b3b5c7} TCPHandler: Code: 53. DB::Exception: Cannot convert string 'a' to type UInt8. (TYPE_MISMATCH), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&, String&&) @ 0x000000000e9e161a 4. ./build_docker/./src/Interpreters/convertFieldToType.cpp:559: DB::(anonymous namespace)::convertFieldToTypeImpl(DB::Field const&, DB::IDataType const&, DB::IDataType const*) @ 0x0000000029aa854f 5. ./build_docker/./src/Interpreters/convertFieldToType.cpp:611: DB::convertFieldToType(DB::Field const&, DB::IDataType const&, DB::IDataType const*) @ 0x0000000029aa2141 6. ./build_docker/./src/Interpreters/convertFieldToType.cpp:0: DB::(anonymous namespace)::convertFieldToTypeImpl(DB::Field const&, DB::IDataType const&, DB::IDataType const*) @ 0x0000000029aa3e34 7. ./build_docker/./src/Interpreters/convertFieldToType.cpp:611: DB::convertFieldToType(DB::Field const&, DB::IDataType const&, DB::IDataType const*) @ 0x0000000029aa2141 8. ./src/Core/Field.h:455: DB::convertFieldToTypeStrict(DB::Field const&, DB::IDataType const&, DB::IDataType const&) @ 0x0000000029aa956b 9. ./contrib/llvm-project/libcxx/include/optional:344: DB::Block DB::(anonymous namespace)::createBlockFromCollection(DB::Array const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, bool) @ 0x0000000028450a80 10. ./contrib/llvm-project/libcxx/include/vector:961: DB::getSetElementsForConstantValue(std::shared_ptr const&, DB::Field const&, std::shared_ptr const&, bool) @ 0x000000002844dd89 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3398: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283990cb 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000028367bce 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028366290 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283b62c9 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002835ae03 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000028359104 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000028357f0d 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002921bdcc 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&) @ 0x000000002941f313 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&) @ 0x0000000029419aef 21. ./contrib/llvm-project/libcxx/include/vector:432: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000029421f5d 22. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000029344c1b 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*) @ 0x0000000029b3703b 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 25. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 26. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 30. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 31. asan_thread_start(void*) @ 0x000000000aa43059 2025.09.09 14:59:28.010449 [ 2753 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:59:28.019159 [ 2745 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:59:28.102057 [ 4023 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 14:59:29.012613 [ 2762 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:59:29.021231 [ 2740 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:59:29.036024 [ 4023 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 14:59:29.996373 [ 13328 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 14:59:30.023264 [ 2741 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:59:30.023772 [ 2748 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:59:31.006787 [ 4023 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 14:59:31.025653 [ 2786 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:59:31.026368 [ 2788 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:59:32.028607 [ 4023 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 14:59:32.029469 [ 2800 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:59:32.037982 [ 2812 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:59:33.032031 [ 2823 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:59:33.040429 [ 2831 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:59:33.084481 [ 4023 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 14:59:34.034764 [ 2850 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:59:34.043198 [ 2843 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:59:34.173079 [ 3612 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 14:59:35.037333 [ 2864 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:59:35.045498 [ 2862 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:59:35.297182 [ 3612 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 14:59:36.039592 [ 2889 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:59:36.047887 [ 2878 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:59:36.286573 [ 3612 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 14:59:36.982982 [ 13328 ] {} DynamicQueryHandler: Code: 452. DB::Exception: Setting max_execution_time shouldn't be greater than 60. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x0000000026f841fa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:368: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f81de0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/find_if.h:25: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f808a4 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000002d065739 10. ./build_docker/./src/Server/HTTPHandler.cpp:705: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000002d06d139 11. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000002d1cc337 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 15. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 16. asan_thread_start(void*) @ 0x000000000aa43059 17. ? @ 0x00007f35aab92ac3 18. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:59:37.041943 [ 2904 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:59:37.049963 [ 2905 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:59:37.229484 [ 3612 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 14:59:38.044246 [ 2942 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:59:38.051980 [ 2944 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:59:38.196663 [ 3329 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {166e6d4b-ecec-41a4-ad4a-0c1c77ff9a47::202509_103_167_13}: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=13, jobs=0). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af80b71 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80746 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002c765aab 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:1197: ? @ 0x000000002c7602b8 8. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x000000002c75fc2b 9. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:0: DB::MergeTreeReaderCompact::MergeTreeReaderCompact(std::shared_ptr, DB::NamesAndTypesList, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*, DB::MarkCache*, DB::MarkRanges, DB::MergeTreeReaderSettings, std::map, std::allocator>>, std::function const&, int) @ 0x000000002c7aee03 10. ./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.h:16: DB::MergeTreeReaderCompactSingleBuffer::MergeTreeReaderCompactSingleBuffer&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int&&) @ 0x000000002c5d6d21 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::MergeTreeDataPartCompact::getReader(DB::NamesAndTypesList const&, std::shared_ptr const&, DB::MarkRanges const&, std::unordered_map, std::equal_to, std::allocator>> const&, DB::UncompressedCache*, DB::MarkCache*, std::shared_ptr const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) const @ 0x000000002c5d1037 12. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:169: DB::MergeTreeSequentialSource::MergeTreeSequentialSource(DB::MergeTreeSequentialSourceType, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::vector>, std::optional, bool, bool, bool) @ 0x000000002c80c330 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:35: DB::MergeTreeSequentialSource* std::construct_at[abi:v15007] const&, std::shared_ptr&, std::shared_ptr&, std::vector>&, std::optional, bool, bool&, bool&, DB::MergeTreeSequentialSource*>(DB::MergeTreeSequentialSource*, DB::MergeTreeSequentialSourceType&, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr&, std::shared_ptr&, std::vector>&, std::optional&&, bool&&, bool&, bool&) @ 0x000000002c81320f 14. ./contrib/llvm-project/libcxx/include/__memory/allocator_traits.h:298: DB::createMergeTreeSequentialSource(DB::MergeTreeSequentialSourceType, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::vector>, std::optional, std::shared_ptr>, bool, bool, bool) @ 0x000000002c810812 15. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1136: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::createMergedStream() @ 0x000000002c3dd079 16. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() @ 0x000000002c3d6516 17. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:534: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x000000002c3e2799 18. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::execute() @ 0x000000002c3ef3fe 19. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:0: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000002cc2f4c0 20. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000002c427f28 21. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000002c429675 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7eaf0 23. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001af8a79f 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 26. asan_thread_start(void*) @ 0x000000000aa43059 27. ? @ 0x00007f35aab92ac3 28. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:59:38.209122 [ 3612 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 14:59:39.046818 [ 2965 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:59:39.055762 [ 2975 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:59:39.234808 [ 3612 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 14:59:40.049559 [ 3008 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:59:40.058161 [ 3005 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:59:40.203304 [ 3612 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 14:59:41.051648 [ 3036 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:59:41.060158 [ 3035 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:59:41.154969 [ 3612 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 14:59:42.053891 [ 3061 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:59:42.062402 [ 3059 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:59:42.098338 [ 3612 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 14:59:42.808245 [ 2688 ] {e0225fed-d537-4e80-ac2d-66ac1b038acb} 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.10505.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:39244) (comment: 01927_query_views_log_current_database.sql) (in query: SELECT 'Depending views 2' AS `stage`, `__table1`.`view_name` AS `view_name`, `__table1`.`view_type` AS `view_type`, `__table1`.`status` AS `status`, `__table1`.`view_target` AS `view_target`, `__table1`.`view_query` AS `view_query`, `__table1`.`read_rows` AS `read_rows`, `__table1`.`written_rows` AS `written_rows`, `__table1`.`ProfileEvents`['SleepFunctionCalls'] AS `sleep_calls`, `__table1`.`ProfileEvents`['SleepFunctionMicroseconds'] AS `sleep_us`, `__table1`.`ProfileEvents`['SelectedRows'] AS `profile_select_rows`, `__table1`.`ProfileEvents`['SelectedBytes'] AS `profile_select_bytes`, `__table1`.`ProfileEvents`['InsertedRows'] AS `profile_insert_rows`, `__table1`.`ProfileEvents`['InsertedBytes'] AS `profile_insert_bytes` FROM `system`.`query_views_log` AS `__table1` WHERE `__table1`.`initial_query_id` = _CAST('709bb7aa-d97f-46c7-b030-99ca2a9873e9', 'Nullable(String)') ORDER BY `__table1`.`view_name` ASC), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af819ed 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80746 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d34b5ca 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000002d3486e4 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000002d34827b 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002d36bcf7 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 12. asan_thread_start(void*) @ 0x000000000aa43059 13. ? @ 0x00007f35aab92ac3 14. ? @ 0x00007f35aac24850 2025.09.09 14:59:42.812858 [ 2688 ] {e0225fed-d537-4e80-ac2d-66ac1b038acb} 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af819ed 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80746 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d34b5ca 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000002d3486e4 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000002d34827b 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002d36bcf7 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 12. asan_thread_start(void*) @ 0x000000000aa43059 13. ? @ 0x00007f35aab92ac3 14. ? @ 0x00007f35aac24850 2025.09.09 14:59:42.905284 [ 4023 ] {1936e0fe-8f64-46c0-a9b6-77cadf924e37} executeQuery: Code: 439. DB::Exception: Received from 127.0.0.10:9000. DB::Exception: Cannot schedule a task: failed to start the thread (threads=1, jobs=1). Stack trace: 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af819ed 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80746 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d34b5ca 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000002d3486e4 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000002d34827b 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002d36bcf7 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 12. asan_thread_start(void*) @ 0x000000000aa43059 13. ? @ 0x00007f35aab92ac3 14. ? @ 0x00007f35aac24850 : While executing Remote. (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:60664) (comment: 01927_query_views_log_current_database.sql) (in query: SELECT 'Depending views 2' as stage, view_name, view_type, status, view_target, view_query, read_rows, written_rows, ProfileEvents['SleepFunctionCalls'] as sleep_calls, ProfileEvents['SleepFunctionMicroseconds'] as sleep_us, ProfileEvents['SelectedRows'] as profile_select_rows, ProfileEvents['SelectedBytes'] as profile_select_bytes, ProfileEvents['InsertedRows'] as profile_insert_rows, ProfileEvents['InsertedBytes'] as profile_insert_bytes FROM system.query_views_log WHERE initial_query_id = ( SELECT initial_query_id FROM system.query_log WHERE query like '-- INSERT 2%INSERT INTO table_d%' AND current_database = currentDatabase() AND event_date >= yesterday() LIMIT 1 ) ORDER BY view_name FORMAT Vertical;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. ./contrib/llvm-project/libcxx/include/string:1499: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x000000001aeb974e 3. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::Connection::receiveException() const @ 0x000000002cee6c6a 4. ./build_docker/./src/Client/Connection.cpp:0: DB::Connection::receivePacket() @ 0x000000002cef780e 5. ./build_docker/./src/Client/MultiplexedConnections.cpp:340: DB::MultiplexedConnections::receivePacketUnlocked(std::function) @ 0x000000002cf8e09e 6. ./build_docker/./src/QueryPipeline/RemoteQueryExecutorReadContext.cpp:0: DB::RemoteQueryExecutorReadContext::Task::run(std::function, std::function) @ 0x00000000278ad616 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000278ab436 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000278aaa44 9. ./contrib/boost/boost/context/fiber_ucontext.hpp:82: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x00000000278a8394 2025.09.09 14:59:42.926268 [ 4023 ] {1936e0fe-8f64-46c0-a9b6-77cadf924e37} TCPHandler: Code: 439. DB::Exception: Received from 127.0.0.10:9000. DB::Exception: Cannot schedule a task: failed to start the thread (threads=1, jobs=1). Stack trace: 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af819ed 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80746 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d34b5ca 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000002d3486e4 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000002d34827b 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002d36bcf7 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 12. asan_thread_start(void*) @ 0x000000000aa43059 13. ? @ 0x00007f35aab92ac3 14. ? @ 0x00007f35aac24850 : 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. ./contrib/llvm-project/libcxx/include/string:1499: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x000000001aeb974e 3. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::Connection::receiveException() const @ 0x000000002cee6c6a 4. ./build_docker/./src/Client/Connection.cpp:0: DB::Connection::receivePacket() @ 0x000000002cef780e 5. ./build_docker/./src/Client/MultiplexedConnections.cpp:340: DB::MultiplexedConnections::receivePacketUnlocked(std::function) @ 0x000000002cf8e09e 6. ./build_docker/./src/QueryPipeline/RemoteQueryExecutorReadContext.cpp:0: DB::RemoteQueryExecutorReadContext::Task::run(std::function, std::function) @ 0x00000000278ad616 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000278ab436 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000278aaa44 9. ./contrib/boost/boost/context/fiber_ucontext.hpp:82: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x00000000278a8394 2025.09.09 14:59:43.056079 [ 3089 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:59:43.064472 [ 4023 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 14:59:43.064471 [ 3088 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:59:44.057334 [ 2688 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 14:59:44.058140 [ 3099 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:59:44.067256 [ 3108 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:59:45.042687 [ 4023 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 14:59:45.060830 [ 3145 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:59:45.069479 [ 3134 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:59:45.659671 [ 3328 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {44b09201-5a0e-4da3-91d1-ac60ea8508c5::202509_1_66_14}: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=13, jobs=0). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af80b71 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80746 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002c765aab 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:1197: ? @ 0x000000002c7602b8 8. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x000000002c75fc2b 9. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:0: DB::MergeTreeReaderCompact::MergeTreeReaderCompact(std::shared_ptr, DB::NamesAndTypesList, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*, DB::MarkCache*, DB::MarkRanges, DB::MergeTreeReaderSettings, std::map, std::allocator>>, std::function const&, int) @ 0x000000002c7aee03 10. ./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.h:16: DB::MergeTreeReaderCompactSingleBuffer::MergeTreeReaderCompactSingleBuffer&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int&&) @ 0x000000002c5d6d21 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::MergeTreeDataPartCompact::getReader(DB::NamesAndTypesList const&, std::shared_ptr const&, DB::MarkRanges const&, std::unordered_map, std::equal_to, std::allocator>> const&, DB::UncompressedCache*, DB::MarkCache*, std::shared_ptr const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) const @ 0x000000002c5d1037 12. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:169: DB::MergeTreeSequentialSource::MergeTreeSequentialSource(DB::MergeTreeSequentialSourceType, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::vector>, std::optional, bool, bool, bool) @ 0x000000002c80c330 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:35: DB::MergeTreeSequentialSource* std::construct_at[abi:v15007] const&, std::shared_ptr&, std::shared_ptr&, std::vector>&, std::optional, bool, bool&, bool&, DB::MergeTreeSequentialSource*>(DB::MergeTreeSequentialSource*, DB::MergeTreeSequentialSourceType&, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr&, std::shared_ptr&, std::vector>&, std::optional&&, bool&&, bool&, bool&) @ 0x000000002c81320f 14. ./contrib/llvm-project/libcxx/include/__memory/allocator_traits.h:298: DB::createMergeTreeSequentialSource(DB::MergeTreeSequentialSourceType, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::vector>, std::optional, std::shared_ptr>, bool, bool, bool) @ 0x000000002c810812 15. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1136: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::createMergedStream() @ 0x000000002c3dd079 16. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() @ 0x000000002c3d6516 17. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:534: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x000000002c3e2799 18. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::execute() @ 0x000000002c3ef3fe 19. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:0: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000002cc2f4c0 20. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000002c427f28 21. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000002c429675 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7eaf0 23. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001af8a79f 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 26. asan_thread_start(void*) @ 0x000000000aa43059 27. ? @ 0x00007f35aab92ac3 28. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:59:46.062636 [ 3168 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:59:46.071531 [ 3172 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:59:46.089818 [ 4023 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 14:59:47.064528 [ 3186 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:59:47.073482 [ 3183 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:59:47.088002 [ 3612 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 14:59:48.067160 [ 3213 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:59:48.111101 [ 3219 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:59:48.140091 [ 4023 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 14:59:49.069456 [ 3234 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:59:49.113368 [ 3238 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:59:49.116578 [ 4023 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 14:59:50.073390 [ 2745 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:59:50.082673 [ 3612 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 14:59:50.115515 [ 2738 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:59:51.075569 [ 2764 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:59:51.117317 [ 3612 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 14:59:51.118041 [ 2755 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:59:52.077926 [ 2776 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:59:52.120382 [ 2782 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:59:52.196157 [ 3612 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 14:59:53.080280 [ 2795 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:59:53.118138 [ 4023 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 14:59:53.122425 [ 2798 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:59:54.070992 [ 3612 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 14:59:54.124749 [ 2832 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:59:54.135320 [ 2817 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:59:55.025119 [ 4023 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 14:59:55.127179 [ 2845 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:59:55.137561 [ 2839 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:59:55.962024 [ 3612 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 14:59:56.135013 [ 2864 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:59:56.139890 [ 2862 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:59:56.976529 [ 3612 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 14:59:57.137045 [ 2885 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:59:57.142016 [ 2882 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:59:57.953890 [ 3612 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 14:59:58.139095 [ 2901 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:59:58.144058 [ 2909 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:59:58.891618 [ 4023 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 14:59:59.141724 [ 2919 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:59:59.146517 [ 2916 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 14:59:59.846367 [ 3612 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 15:00:00.144213 [ 2938 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:00:00.148685 [ 2936 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:00:00.855539 [ 3612 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 15:00:01.150397 [ 2962 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:00:01.151374 [ 2963 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:00:01.911289 [ 3612 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 15:00:02.152527 [ 2989 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:00:02.153442 [ 2982 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:00:02.917733 [ 4023 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 15:00:03.154850 [ 3004 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:00:03.155485 [ 3008 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:00:03.963961 [ 3612 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 15:00:04.157000 [ 3030 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:00:04.157329 [ 3023 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:00:04.921011 [ 3612 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 15:00:05.159871 [ 3046 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:00:05.160559 [ 3044 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:00:05.468814 [ 13328 ] {} DynamicQueryHandler: Code: 452. DB::Exception: Setting max_execution_time shouldn't be greater than 60. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x0000000026f841fa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:368: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f81de0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/find_if.h:25: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f808a4 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000002d065739 10. ./build_docker/./src/Server/HTTPHandler.cpp:705: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000002d06d139 11. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000002d1cc337 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 15. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 16. asan_thread_start(void*) @ 0x000000000aa43059 17. ? @ 0x00007f35aab92ac3 18. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:00:05.948904 [ 3612 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 15:00:06.162513 [ 3077 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:00:06.163137 [ 3078 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:00:06.901974 [ 3612 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 15:00:07.164815 [ 3100 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:00:07.165847 [ 3103 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:00:07.901050 [ 4023 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 15:00:08.167520 [ 3115 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:00:08.168589 [ 3121 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:00:09.016983 [ 4023 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 15:00:09.170862 [ 3141 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:00:09.171559 [ 3143 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:00:09.968395 [ 4023 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 15:00:10.172704 [ 3169 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:00:10.173481 [ 3173 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:00:10.943072 [ 4023 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 15:00:11.174853 [ 3191 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:00:11.175810 [ 3194 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:00:11.880847 [ 3612 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 15:00:12.177368 [ 3230 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:00:12.178078 [ 3223 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:00:12.844910 [ 3612 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 15:00:13.181638 [ 2732 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:00:13.181724 [ 2750 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:00:13.946227 [ 3612 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 15:00:14.184750 [ 2749 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:00:14.195395 [ 2759 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:00:15.053192 [ 3612 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 15:00:15.187189 [ 2748 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:00:15.197518 [ 2767 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:00:16.014880 [ 3612 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 15:00:16.189259 [ 2795 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:00:16.199484 [ 2806 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:00:16.951648 [ 3612 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 15:00:17.191453 [ 2824 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:00:17.201641 [ 2826 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:00:17.912284 [ 4023 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 15:00:18.193540 [ 2848 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:00:18.203548 [ 2845 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:00:18.921160 [ 3612 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 15:00:19.196633 [ 2865 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:00:19.206330 [ 2866 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:00:19.907079 [ 4023 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 15:00:20.199610 [ 2889 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:00:20.209379 [ 2885 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:00:20.820144 [ 4023 ] {d0898119-17d3-48df-acc5-7f09a169d3f4} executeQuery: Code: 158. DB::Exception: Limit for rows or bytes to read exceeded, max rows: 2.00, current rows: 4.00: While executing Remote. (TOO_MANY_ROWS) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:34506) (comment: 02346_additional_filters_index.sql) (in query: select * from table_1 order by x settings additional_table_filters={'table_1' : '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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, String&&, String&&) @ 0x00000000278b34e0 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:24: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b3073 5. ./build_docker/./src/QueryPipeline/ReadProgressCallback.cpp:109: DB::ReadProgressCallback::onProgress(unsigned long, unsigned long, std::list> const&) @ 0x0000000027854fe0 6. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:62: DB::ExecutionThreadContext::executeTask() @ 0x000000002d3630e8 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:381: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000002d34bd35 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7eaf0 10. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001af8a79f 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 13. asan_thread_start(void*) @ 0x000000000aa43059 14. ? @ 0x00007f35aab92ac3 15. ? @ 0x00007f35aac24850 2025.09.09 15:00:20.825507 [ 4025 ] {} ServerErrorHandler: Code: 210. DB::NetException: Connection reset by peer, while reading from socket (peer: [::ffff:127.0.0.1]:37276, local: [::ffff:127.0.0.1]:9000). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 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&&) @ 0x000000001b0b7a5f 3. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:83: DB::ReadBufferFromPocoSocketBase::socketReceiveBytesImpl(char*, unsigned long) @ 0x000000001b0b6042 4. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:107: DB::ReadBufferFromPocoSocketBase::nextImpl() @ 0x000000001b0b6b84 5. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:103: DB::ReadBufferFromPocoSocketChunked::nextImpl() @ 0x000000002cf045f6 6. DB::ReadBuffer::next() @ 0x000000000b528aeb 7. ./build_docker/./src/Server/TCPHandler.cpp:383: DB::TCPHandler::runImpl() @ 0x000000002d174fd3 8. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 12. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 13. asan_thread_start(void*) @ 0x000000000aa43059 14. ? @ 0x00007f35aab92ac3 15. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:00:20.833099 [ 12628 ] {} ServerErrorHandler: Code: 210. DB::NetException: Connection reset by peer, while reading from socket (peer: [::ffff:127.0.0.1]:47882, local: [::ffff:127.0.0.6]:9000). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 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&&) @ 0x000000001b0b7a5f 3. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:83: DB::ReadBufferFromPocoSocketBase::socketReceiveBytesImpl(char*, unsigned long) @ 0x000000001b0b6042 4. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:107: DB::ReadBufferFromPocoSocketBase::nextImpl() @ 0x000000001b0b6b84 5. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:103: DB::ReadBufferFromPocoSocketChunked::nextImpl() @ 0x000000002cf045f6 6. DB::ReadBuffer::next() @ 0x000000000b528aeb 7. ./build_docker/./src/Server/TCPHandler.cpp:383: DB::TCPHandler::runImpl() @ 0x000000002d174fd3 8. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 12. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 13. asan_thread_start(void*) @ 0x000000000aa43059 14. ? @ 0x00007f35aab92ac3 15. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:00:20.836839 [ 3604 ] {} ServerErrorHandler: Code: 210. DB::NetException: Connection reset by peer, while reading from socket (peer: [::ffff:127.0.0.1]:55048, local: [::ffff:127.0.0.9]: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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 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&&) @ 0x000000001b0b7a5f 3. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:83: DB::ReadBufferFromPocoSocketBase::socketReceiveBytesImpl(char*, unsigned long) @ 0x000000001b0b6042 4. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:107: DB::ReadBufferFromPocoSocketBase::nextImpl() @ 0x000000001b0b6b84 5. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:103: DB::ReadBufferFromPocoSocketChunked::nextImpl() @ 0x000000002cf045f6 6. DB::ReadBuffer::next() @ 0x000000000b528aeb 7. ./build_docker/./src/Server/TCPHandler.cpp:383: DB::TCPHandler::runImpl() @ 0x000000002d174fd3 8. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 12. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 13. asan_thread_start(void*) @ 0x000000000aa43059 14. ? @ 0x00007f35aab92ac3 15. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:00:20.837417 [ 4023 ] {d0898119-17d3-48df-acc5-7f09a169d3f4} TCPHandler: Code: 158. DB::Exception: Limit for rows or bytes to read exceeded, max rows: 2.00, current rows: 4.00: 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, String&&, String&&) @ 0x00000000278b34e0 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:24: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b3073 5. ./build_docker/./src/QueryPipeline/ReadProgressCallback.cpp:109: DB::ReadProgressCallback::onProgress(unsigned long, unsigned long, std::list> const&) @ 0x0000000027854fe0 6. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:62: DB::ExecutionThreadContext::executeTask() @ 0x000000002d3630e8 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:381: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000002d34bd35 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7eaf0 10. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001af8a79f 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 13. asan_thread_start(void*) @ 0x000000000aa43059 14. ? @ 0x00007f35aab92ac3 15. ? @ 0x00007f35aac24850 2025.09.09 15:00:20.996508 [ 4023 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 15:00:21.201879 [ 2904 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:00:21.211777 [ 2911 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:00:22.049363 [ 4023 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 15:00:22.261075 [ 2924 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:00:22.261532 [ 2931 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:00:23.009662 [ 3612 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 15:00:23.263482 [ 2945 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:00:23.263969 [ 2953 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:00:24.016863 [ 4023 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 15:00:24.265706 [ 2969 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:00:24.266231 [ 2971 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:00:24.919163 [ 4023 ] {1a8d5621-180b-4b35-8c9c-f54eed10fe3e} executeQuery: Code: 57. DB::Exception: Table test_3.bloom_filter_idx already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:34570) (comment: 00944_create_bloom_filter_index_with_merge_tree.sh) (in query: CREATE TABLE bloom_filter_idx (`u64` UInt64, `i32` Int32, `f64` Float64, `d` Decimal(10, 2), `s` String, `e` Enum8('a' = 1, 'b' = 2, 'c' = 3), `dt` Date, INDEX bloom_filter_a i32 TYPE bloom_filter(0.1) GRANULARITY 1) ENGINE = MergeTree ORDER BY u64 SETTINGS index_granularity = 8192, min_bytes_for_wide_part = 1073741824, ratio_of_defaults_for_sparse_serialization = 0., replace_long_file_name_to_hash = false, max_file_name_length = 128, min_bytes_for_full_part_storage = 346862087, compact_parts_max_bytes_to_buffer = 134122494, compact_parts_max_granules_to_buffer = 141, compact_parts_merge_max_bytes_to_prefetch_part = 17436970, merge_max_block_size = 6192, old_parts_lifetime = 480., prefer_fetch_merged_part_size_threshold = 10737418240, vertical_merge_algorithm_min_rows_to_activate = 1, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 10737418240, index_granularity_bytes = 6897962, concurrent_part_removal_threshold = 100, allow_vertical_merges_from_compact_to_wide_parts = false, cache_populated_by_fetch = false, marks_compress_block_size = 12525, primary_key_compress_block_size = 38683), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa91e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1558: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291bc5ff 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291ac835 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000291c3415 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b382fc 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 15. asan_thread_start(void*) @ 0x000000000aa43059 16. ? @ 0x00007f35aab92ac3 17. ? @ 0x00007f35aac24850 2025.09.09 15:00:24.925298 [ 4023 ] {1a8d5621-180b-4b35-8c9c-f54eed10fe3e} TCPHandler: Code: 57. DB::Exception: Table test_3.bloom_filter_idx already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa91e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1558: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291bc5ff 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291ac835 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000291c3415 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b382fc 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 15. asan_thread_start(void*) @ 0x000000000aa43059 16. ? @ 0x00007f35aab92ac3 17. ? @ 0x00007f35aac24850 2025.09.09 15:00:25.091370 [ 4023 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 15:00:25.268207 [ 2995 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:00:25.268234 [ 2984 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:00:25.847079 [ 4023 ] {c1e41098-0a28-42f1-b9bc-b8c0a49427ec} executeQuery: Code: 636. DB::Exception: The table structure cannot be extracted from a Native format file. Error: Code: 128. DB::Exception: Array sizes are too large: 13830481612736675823. (TOO_LARGE_ARRAY_SIZE) (version 24.8.14.10505.altinitytest (altinity build)). You can specify the structure manually. (CANNOT_EXTRACT_TABLE_STRUCTURE) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:34576) (comment: 02426_pod_array_overflow_2.sql) (in query: SELECT * FROM format(Native, 'k0\x23Array(Tuple(FixedString(1), Int64))\0\0\0\0\0\0\0�����\0����������������\0�\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0d\0\0\0\0\0\0\0\0\0\0\0\0\0�1?Vi�%');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&, String&) @ 0x00000000180b4b3a 4. ./build_docker/./src/Formats/ReadSchemaUtils.cpp:280: DB::readSchemaFromFormatImpl(std::optional, std::optional const&, DB::IReadBufferIterator&, std::shared_ptr const&) @ 0x000000002d2c2ce6 5. ./build_docker/./src/Formats/ReadSchemaUtils.cpp:0: DB::readSchemaFromFormat(String const&, std::optional const&, DB::IReadBufferIterator&, std::shared_ptr const&) @ 0x000000002d2c4e9b 6. ./build_docker/./src/TableFunctions/TableFunctionFormat.cpp:0: DB::(anonymous namespace)::TableFunctionFormat::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x0000000026040290 7. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x00000000265c241e 8. ./build_docker/./src/Interpreters/Context.cpp:2234: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000285361d2 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4819: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000002837024e 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000283ba404 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002835ad09 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000028359104 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000028357f0d 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002921bdcc 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&) @ 0x000000002941f313 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&) @ 0x0000000029419aef 17. ./contrib/llvm-project/libcxx/include/vector:432: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000029421f5d 18. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000029344c1b 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*) @ 0x0000000029b3703b 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 21. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 22. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 26. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 27. asan_thread_start(void*) @ 0x000000000aa43059 28. ? @ 0x00007f35aab92ac3 29. ? @ 0x00007f35aac24850 2025.09.09 15:00:25.857401 [ 4023 ] {c1e41098-0a28-42f1-b9bc-b8c0a49427ec} TCPHandler: Code: 636. DB::Exception: The table structure cannot be extracted from a Native format file. Error: Code: 128. DB::Exception: Array sizes are too large: 13830481612736675823. (TOO_LARGE_ARRAY_SIZE) (version 24.8.14.10505.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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&, String&) @ 0x00000000180b4b3a 4. ./build_docker/./src/Formats/ReadSchemaUtils.cpp:280: DB::readSchemaFromFormatImpl(std::optional, std::optional const&, DB::IReadBufferIterator&, std::shared_ptr const&) @ 0x000000002d2c2ce6 5. ./build_docker/./src/Formats/ReadSchemaUtils.cpp:0: DB::readSchemaFromFormat(String const&, std::optional const&, DB::IReadBufferIterator&, std::shared_ptr const&) @ 0x000000002d2c4e9b 6. ./build_docker/./src/TableFunctions/TableFunctionFormat.cpp:0: DB::(anonymous namespace)::TableFunctionFormat::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x0000000026040290 7. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x00000000265c241e 8. ./build_docker/./src/Interpreters/Context.cpp:2234: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000285361d2 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4819: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000002837024e 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000283ba404 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002835ad09 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000028359104 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000028357f0d 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002921bdcc 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&) @ 0x000000002941f313 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&) @ 0x0000000029419aef 17. ./contrib/llvm-project/libcxx/include/vector:432: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000029421f5d 18. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000029344c1b 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*) @ 0x0000000029b3703b 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 21. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 22. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 26. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 27. asan_thread_start(void*) @ 0x000000000aa43059 28. ? @ 0x00007f35aab92ac3 29. ? @ 0x00007f35aac24850 2025.09.09 15:00:26.033083 [ 4023 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 15:00:26.270113 [ 3018 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:00:26.270445 [ 3024 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:00:27.100298 [ 4023 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 15:00:27.272952 [ 3038 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:00:27.273496 [ 3041 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:00:28.107280 [ 3612 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 15:00:28.275407 [ 3053 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:00:28.275600 [ 3055 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:00:28.460580 [ 4023 ] {52344f5f-3c32-4783-bece-a08e40b3671a} 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.10505.altinitytest (altinity build)) (from [::1]:34628) (comment: 00444_join_use_nulls.sql) (in query: SELECT k, a, b FROM ( SELECT number AS k, toString(number) AS a FROM system.numbers LIMIT 10 ) ANY LEFT JOIN ( SELECT number AS k, toString(number) AS b FROM system.numbers LIMIT 5, 10 ) USING (k) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aac868e 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&) @ 0x00000000294a6d9f 5. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1490: DB::(anonymous namespace)::buildQueryPlanForJoinNode(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000002947642f 6. ./build_docker/./src/Planner/PlannerJoinTree.cpp:0: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000002945f174 7. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x000000002942c986 8. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x00000000294261fb 9. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000029421552 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1182: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3737e 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 13. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 18. asan_thread_start(void*) @ 0x000000000aa43059 19. ? @ 0x00007f35aab92ac3 20. ? @ 0x00007f35aac24850 2025.09.09 15:00:28.464181 [ 4023 ] {52344f5f-3c32-4783-bece-a08e40b3671a} 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aac868e 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&) @ 0x00000000294a6d9f 5. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1490: DB::(anonymous namespace)::buildQueryPlanForJoinNode(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000002947642f 6. ./build_docker/./src/Planner/PlannerJoinTree.cpp:0: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000002945f174 7. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x000000002942c986 8. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x00000000294261fb 9. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000029421552 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1182: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3737e 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 13. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 18. asan_thread_start(void*) @ 0x000000000aa43059 19. ? @ 0x00007f35aab92ac3 20. ? @ 0x00007f35aac24850 2025.09.09 15:00:29.038275 [ 3612 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 15:00:29.256956 [ 4023 ] {ccb9703c-5c34-48e0-a791-d82debae9a53} executeQuery: Code: 36. DB::Exception: Time overflow in function hop: In scope SELECT hop(toDateTime(0), toIntervalDay(1), toIntervalDay(3)). (BAD_ARGUMENTS) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:52218) (comment: 03013_hop_infinite_loop.sql) (in query: SELECT hop(toDateTime(0), INTERVAL 1 DAY, INTERVAL 3 DAY);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const* const&) @ 0x000000000ab2a714 4. DB::(anonymous namespace)::TimeWindowImpl<(DB::(anonymous namespace)::TimeWindowFunctionName)3>::dispatchForColumns(std::vector> const&, String const&, unsigned long) @ 0x000000000cca888d 5. DB::(anonymous namespace)::FunctionTimeWindow<(DB::(anonymous namespace)::TimeWindowFunctionName)3>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000cca2541 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aa8c635 7. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aac91d5 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000cccccfb 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000cccc1ab 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccccc2a 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccce65c 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd2030 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002839a3af 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000028367bce 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028366290 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283b62c9 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002835ae03 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000028359104 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000028357f0d 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002921bdcc 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&) @ 0x000000002941f313 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&) @ 0x0000000029419aef 23. ./contrib/llvm-project/libcxx/include/vector:432: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000029421f5d 24. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000029344c1b 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*) @ 0x0000000029b3703b 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 27. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 28. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 2025.09.09 15:00:29.261477 [ 4023 ] {ccb9703c-5c34-48e0-a791-d82debae9a53} TCPHandler: Code: 36. DB::Exception: Time overflow in function hop: In scope SELECT hop(toDateTime(0), toIntervalDay(1), toIntervalDay(3)). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const* const&) @ 0x000000000ab2a714 4. DB::(anonymous namespace)::TimeWindowImpl<(DB::(anonymous namespace)::TimeWindowFunctionName)3>::dispatchForColumns(std::vector> const&, String const&, unsigned long) @ 0x000000000cca888d 5. DB::(anonymous namespace)::FunctionTimeWindow<(DB::(anonymous namespace)::TimeWindowFunctionName)3>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000cca2541 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aa8c635 7. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aac91d5 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000cccccfb 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000cccc1ab 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccccc2a 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccce65c 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd2030 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002839a3af 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000028367bce 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028366290 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283b62c9 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002835ae03 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000028359104 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000028357f0d 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002921bdcc 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&) @ 0x000000002941f313 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&) @ 0x0000000029419aef 23. ./contrib/llvm-project/libcxx/include/vector:432: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000029421f5d 24. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000029344c1b 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*) @ 0x0000000029b3703b 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 27. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 28. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 2025.09.09 15:00:29.279532 [ 3072 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:00:29.348946 [ 3071 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:00:30.073028 [ 3612 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 15:00:30.281759 [ 3083 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:00:30.351399 [ 3097 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:00:30.992775 [ 4023 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 15:00:31.283898 [ 3127 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:00:31.353394 [ 3122 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:00:32.015982 [ 4023 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 15:00:32.285897 [ 3142 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:00:32.355288 [ 3140 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:00:33.013521 [ 4023 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 15:00:33.288037 [ 3159 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:00:33.357353 [ 3166 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:00:34.017801 [ 3612 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 15:00:34.359548 [ 3185 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:00:34.362451 [ 3184 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:00:34.991989 [ 3612 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 15:00:35.361965 [ 3203 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:00:35.364522 [ 3205 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:00:35.509765 [ 4023 ] {8038c490-71ad-4b81-bcfd-b4448ee5da15} executeQuery: Code: 27. DB::Exception: Cannot parse input: expected ',' before: '\n': (at row 1) : Could not print diagnostic info because two last rows aren't in buffer (rare case) : (in file/uri /var/lib/clickhouse/user_files/test_02270_2.csv): While executing CSVRowInputFormat: While executing File. (CANNOT_PARSE_INPUT_ASSERTION_FAILED) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:52318) (comment: 02270_errors_in_files.sh) (in query: SELECT * FROM file('test_02270*.csv', 'CSV', 'a String, b 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::throwAtAssertionFailed(char const*, DB::ReadBuffer&) @ 0x000000001aeb2ed5 4. ./src/IO/ReadBuffer.h:114: DB::CSVFormatReader::skipFieldDelimiter() @ 0x000000002d521ecf 5. ./build_docker/./src/Processors/Formats/RowInputFormatWithNamesAndTypes.cpp:0: DB::RowInputFormatWithNamesAndTypes::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x000000002d4ba068 6. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:0: DB::IRowInputFormat::read() @ 0x000000002d46d965 7. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000002d37a746 8. ./src/Processors/Chunk.h:110: DB::ISource::tryGenerate() @ 0x000000002d329c18 9. ./build_docker/./src/Processors/ISource.cpp:0: DB::ISource::work() @ 0x000000002d3290a1 10. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 13. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 14. ./build_docker/./src/Storages/StorageFile.cpp:1454: DB::StorageFileSource::generate() @ 0x000000002b7988be 15. ./src/Processors/Chunk.h:110: DB::ISource::tryGenerate() @ 0x000000002d329c18 16. ./build_docker/./src/Processors/ISource.cpp:0: DB::ISource::work() @ 0x000000002d3290a1 17. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 18. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000002d34877c 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000002d34827b 21. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002d36bcf7 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 24. asan_thread_start(void*) @ 0x000000000aa43059 25. ? @ 0x00007f35aab92ac3 26. ? @ 0x00007f35aac24850 2025.09.09 15:00:35.538227 [ 4023 ] {8038c490-71ad-4b81-bcfd-b4448ee5da15} TCPHandler: Code: 27. DB::Exception: Cannot parse input: expected ',' before: '\n': (at row 1) : Could not print diagnostic info because two last rows aren't in buffer (rare case) : (in file/uri /var/lib/clickhouse/user_files/test_02270_2.csv): While executing CSVRowInputFormat: While executing File. (CANNOT_PARSE_INPUT_ASSERTION_FAILED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::throwAtAssertionFailed(char const*, DB::ReadBuffer&) @ 0x000000001aeb2ed5 4. ./src/IO/ReadBuffer.h:114: DB::CSVFormatReader::skipFieldDelimiter() @ 0x000000002d521ecf 5. ./build_docker/./src/Processors/Formats/RowInputFormatWithNamesAndTypes.cpp:0: DB::RowInputFormatWithNamesAndTypes::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x000000002d4ba068 6. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:0: DB::IRowInputFormat::read() @ 0x000000002d46d965 7. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000002d37a746 8. ./src/Processors/Chunk.h:110: DB::ISource::tryGenerate() @ 0x000000002d329c18 9. ./build_docker/./src/Processors/ISource.cpp:0: DB::ISource::work() @ 0x000000002d3290a1 10. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 13. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 14. ./build_docker/./src/Storages/StorageFile.cpp:1454: DB::StorageFileSource::generate() @ 0x000000002b7988be 15. ./src/Processors/Chunk.h:110: DB::ISource::tryGenerate() @ 0x000000002d329c18 16. ./build_docker/./src/Processors/ISource.cpp:0: DB::ISource::work() @ 0x000000002d3290a1 17. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 18. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000002d34877c 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000002d34827b 21. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002d36bcf7 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 24. asan_thread_start(void*) @ 0x000000000aa43059 25. ? @ 0x00007f35aab92ac3 26. ? @ 0x00007f35aac24850 2025.09.09 15:00:35.955525 [ 4023 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 15:00:36.073352 [ 3612 ] {1f9e99f6-d36b-488c-8486-293ab551a756} executeQuery: Code: 27. DB::Exception: Cannot parse input: expected ',' before: '\n': (at row 1) : Could not print diagnostic info because two last rows aren't in buffer (rare case) : (in file/uri /var/lib/clickhouse/user_files/test_02270_2.csv): While executing CSVRowInputFormat: While executing File. (CANNOT_PARSE_INPUT_ASSERTION_FAILED) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:52338) (comment: 02270_errors_in_files.sh) (in query: SELECT * FROM file('test_02270*.csv', 'CSV', 'a String, b 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::throwAtAssertionFailed(char const*, DB::ReadBuffer&) @ 0x000000001aeb2ed5 4. ./src/IO/ReadBuffer.h:114: DB::CSVFormatReader::skipFieldDelimiter() @ 0x000000002d521ecf 5. ./build_docker/./src/Processors/Formats/RowInputFormatWithNamesAndTypes.cpp:0: DB::RowInputFormatWithNamesAndTypes::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x000000002d4ba068 6. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:0: DB::IRowInputFormat::read() @ 0x000000002d46d965 7. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000002d37a746 8. ./src/Processors/Chunk.h:110: DB::ISource::tryGenerate() @ 0x000000002d329c18 9. ./build_docker/./src/Processors/ISource.cpp:0: DB::ISource::work() @ 0x000000002d3290a1 10. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 13. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 14. ./build_docker/./src/Storages/StorageFile.cpp:1454: DB::StorageFileSource::generate() @ 0x000000002b7988be 15. ./src/Processors/Chunk.h:110: DB::ISource::tryGenerate() @ 0x000000002d329c18 16. ./build_docker/./src/Processors/ISource.cpp:0: DB::ISource::work() @ 0x000000002d3290a1 17. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 18. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000002d34877c 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000002d34827b 21. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002d36bcf7 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 24. asan_thread_start(void*) @ 0x000000000aa43059 25. ? @ 0x00007f35aab92ac3 26. ? @ 0x00007f35aac24850 2025.09.09 15:00:36.077595 [ 3612 ] {1f9e99f6-d36b-488c-8486-293ab551a756} TCPHandler: Code: 27. DB::Exception: Cannot parse input: expected ',' before: '\n': (at row 1) : Could not print diagnostic info because two last rows aren't in buffer (rare case) : (in file/uri /var/lib/clickhouse/user_files/test_02270_2.csv): While executing CSVRowInputFormat: While executing File. (CANNOT_PARSE_INPUT_ASSERTION_FAILED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::throwAtAssertionFailed(char const*, DB::ReadBuffer&) @ 0x000000001aeb2ed5 4. ./src/IO/ReadBuffer.h:114: DB::CSVFormatReader::skipFieldDelimiter() @ 0x000000002d521ecf 5. ./build_docker/./src/Processors/Formats/RowInputFormatWithNamesAndTypes.cpp:0: DB::RowInputFormatWithNamesAndTypes::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x000000002d4ba068 6. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:0: DB::IRowInputFormat::read() @ 0x000000002d46d965 7. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000002d37a746 8. ./src/Processors/Chunk.h:110: DB::ISource::tryGenerate() @ 0x000000002d329c18 9. ./build_docker/./src/Processors/ISource.cpp:0: DB::ISource::work() @ 0x000000002d3290a1 10. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 13. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 14. ./build_docker/./src/Storages/StorageFile.cpp:1454: DB::StorageFileSource::generate() @ 0x000000002b7988be 15. ./src/Processors/Chunk.h:110: DB::ISource::tryGenerate() @ 0x000000002d329c18 16. ./build_docker/./src/Processors/ISource.cpp:0: DB::ISource::work() @ 0x000000002d3290a1 17. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 18. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000002d34877c 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000002d34827b 21. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002d36bcf7 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 24. asan_thread_start(void*) @ 0x000000000aa43059 25. ? @ 0x00007f35aab92ac3 26. ? @ 0x00007f35aac24850 2025.09.09 15:00:36.365105 [ 3216 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:00:36.366621 [ 3227 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:00:36.937366 [ 3612 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 15:00:37.367181 [ 3243 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:00:37.368641 [ 3242 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:00:38.024800 [ 4023 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 15:00:38.245835 [ 4023 ] {3dbbc355-a18c-4c52-a571-54adbf331730} executeQuery: Code: 27. DB::Exception: Cannot parse input: expected ',' before: '\n': (at row 1) : Could not print diagnostic info because two last rows aren't in buffer (rare case) : (in file/uri /var/lib/clickhouse/user_files/test_02270_2.csv.gz): While executing CSVRowInputFormat: While executing File. (CANNOT_PARSE_INPUT_ASSERTION_FAILED) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:47302) (comment: 02270_errors_in_files.sh) (in query: SELECT * FROM file('test_02270*.csv.gz', 'CSV', 'a String, b 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::throwAtAssertionFailed(char const*, DB::ReadBuffer&) @ 0x000000001aeb2ed5 4. ./src/IO/ReadBuffer.h:114: DB::CSVFormatReader::skipFieldDelimiter() @ 0x000000002d521ecf 5. ./build_docker/./src/Processors/Formats/RowInputFormatWithNamesAndTypes.cpp:0: DB::RowInputFormatWithNamesAndTypes::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x000000002d4ba068 6. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:0: DB::IRowInputFormat::read() @ 0x000000002d46d965 7. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000002d37a746 8. ./src/Processors/Chunk.h:110: DB::ISource::tryGenerate() @ 0x000000002d329c18 9. ./build_docker/./src/Processors/ISource.cpp:0: DB::ISource::work() @ 0x000000002d3290a1 10. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 13. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 14. ./build_docker/./src/Storages/StorageFile.cpp:1454: DB::StorageFileSource::generate() @ 0x000000002b7988be 15. ./src/Processors/Chunk.h:110: DB::ISource::tryGenerate() @ 0x000000002d329c18 16. ./build_docker/./src/Processors/ISource.cpp:0: DB::ISource::work() @ 0x000000002d3290a1 17. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 18. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000002d34877c 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000002d34827b 21. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002d36bcf7 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 24. asan_thread_start(void*) @ 0x000000000aa43059 25. ? @ 0x00007f35aab92ac3 26. ? @ 0x00007f35aac24850 2025.09.09 15:00:38.250767 [ 4023 ] {3dbbc355-a18c-4c52-a571-54adbf331730} TCPHandler: Code: 27. DB::Exception: Cannot parse input: expected ',' before: '\n': (at row 1) : Could not print diagnostic info because two last rows aren't in buffer (rare case) : (in file/uri /var/lib/clickhouse/user_files/test_02270_2.csv.gz): While executing CSVRowInputFormat: While executing File. (CANNOT_PARSE_INPUT_ASSERTION_FAILED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::throwAtAssertionFailed(char const*, DB::ReadBuffer&) @ 0x000000001aeb2ed5 4. ./src/IO/ReadBuffer.h:114: DB::CSVFormatReader::skipFieldDelimiter() @ 0x000000002d521ecf 5. ./build_docker/./src/Processors/Formats/RowInputFormatWithNamesAndTypes.cpp:0: DB::RowInputFormatWithNamesAndTypes::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x000000002d4ba068 6. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:0: DB::IRowInputFormat::read() @ 0x000000002d46d965 7. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000002d37a746 8. ./src/Processors/Chunk.h:110: DB::ISource::tryGenerate() @ 0x000000002d329c18 9. ./build_docker/./src/Processors/ISource.cpp:0: DB::ISource::work() @ 0x000000002d3290a1 10. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 13. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 14. ./build_docker/./src/Storages/StorageFile.cpp:1454: DB::StorageFileSource::generate() @ 0x000000002b7988be 15. ./src/Processors/Chunk.h:110: DB::ISource::tryGenerate() @ 0x000000002d329c18 16. ./build_docker/./src/Processors/ISource.cpp:0: DB::ISource::work() @ 0x000000002d3290a1 17. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 18. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000002d34877c 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000002d34827b 21. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002d36bcf7 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 24. asan_thread_start(void*) @ 0x000000000aa43059 25. ? @ 0x00007f35aab92ac3 26. ? @ 0x00007f35aac24850 2025.09.09 15:00:38.370413 [ 2756 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:00:38.371575 [ 2751 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:00:38.910933 [ 4023 ] {2d09c945-1f67-46f3-a95a-c2d9ccd5702a} executeQuery: Code: 27. DB::Exception: Cannot parse input: expected ',' before: '\n': (at row 1) : Could not print diagnostic info because two last rows aren't in buffer (rare case) : (in file/uri /var/lib/clickhouse/user_files/test_02270_2.csv.gz): While executing CSVRowInputFormat: While executing File. (CANNOT_PARSE_INPUT_ASSERTION_FAILED) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:47308) (comment: 02270_errors_in_files.sh) (in query: SELECT * FROM file('test_02270*.csv.gz', 'CSV', 'a String, b 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::throwAtAssertionFailed(char const*, DB::ReadBuffer&) @ 0x000000001aeb2ed5 4. ./src/IO/ReadBuffer.h:114: DB::CSVFormatReader::skipFieldDelimiter() @ 0x000000002d521ecf 5. ./build_docker/./src/Processors/Formats/RowInputFormatWithNamesAndTypes.cpp:0: DB::RowInputFormatWithNamesAndTypes::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x000000002d4ba068 6. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:0: DB::IRowInputFormat::read() @ 0x000000002d46d965 7. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000002d37a746 8. ./src/Processors/Chunk.h:110: DB::ISource::tryGenerate() @ 0x000000002d329c18 9. ./build_docker/./src/Processors/ISource.cpp:0: DB::ISource::work() @ 0x000000002d3290a1 10. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 13. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 14. ./build_docker/./src/Storages/StorageFile.cpp:1454: DB::StorageFileSource::generate() @ 0x000000002b7988be 15. ./src/Processors/Chunk.h:110: DB::ISource::tryGenerate() @ 0x000000002d329c18 16. ./build_docker/./src/Processors/ISource.cpp:0: DB::ISource::work() @ 0x000000002d3290a1 17. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 18. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000002d34877c 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000002d34827b 21. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002d36bcf7 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 24. asan_thread_start(void*) @ 0x000000000aa43059 25. ? @ 0x00007f35aab92ac3 26. ? @ 0x00007f35aac24850 2025.09.09 15:00:38.937343 [ 4023 ] {2d09c945-1f67-46f3-a95a-c2d9ccd5702a} TCPHandler: Code: 27. DB::Exception: Cannot parse input: expected ',' before: '\n': (at row 1) : Could not print diagnostic info because two last rows aren't in buffer (rare case) : (in file/uri /var/lib/clickhouse/user_files/test_02270_2.csv.gz): While executing CSVRowInputFormat: While executing File. (CANNOT_PARSE_INPUT_ASSERTION_FAILED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::throwAtAssertionFailed(char const*, DB::ReadBuffer&) @ 0x000000001aeb2ed5 4. ./src/IO/ReadBuffer.h:114: DB::CSVFormatReader::skipFieldDelimiter() @ 0x000000002d521ecf 5. ./build_docker/./src/Processors/Formats/RowInputFormatWithNamesAndTypes.cpp:0: DB::RowInputFormatWithNamesAndTypes::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x000000002d4ba068 6. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:0: DB::IRowInputFormat::read() @ 0x000000002d46d965 7. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000002d37a746 8. ./src/Processors/Chunk.h:110: DB::ISource::tryGenerate() @ 0x000000002d329c18 9. ./build_docker/./src/Processors/ISource.cpp:0: DB::ISource::work() @ 0x000000002d3290a1 10. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 13. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 14. ./build_docker/./src/Storages/StorageFile.cpp:1454: DB::StorageFileSource::generate() @ 0x000000002b7988be 15. ./src/Processors/Chunk.h:110: DB::ISource::tryGenerate() @ 0x000000002d329c18 16. ./build_docker/./src/Processors/ISource.cpp:0: DB::ISource::work() @ 0x000000002d3290a1 17. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 18. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000002d34877c 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000002d34827b 21. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002d36bcf7 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 24. asan_thread_start(void*) @ 0x000000000aa43059 25. ? @ 0x00007f35aab92ac3 26. ? @ 0x00007f35aac24850 2025.09.09 15:00:38.989555 [ 3612 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 15:00:39.376931 [ 2748 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:00:39.377129 [ 2767 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:00:39.987728 [ 3612 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 15:00:40.388360 [ 2787 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:00:40.388896 [ 2786 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:00:40.942677 [ 3612 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 15:00:41.390958 [ 2818 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:00:41.391307 [ 2804 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:00:41.920702 [ 3612 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 15:00:42.393155 [ 2834 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:00:42.393608 [ 2827 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:00:42.725194 [ 4023 ] {9a0e57f5-07fa-4d20-9dd9-f6f7852e4af9} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=0, jobs=0): The table structure cannot be extracted from a CSV format file. You can specify the structure manually. (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:47346) (comment: 03036_reading_s3_archives.sql) (in query: SELECT id, data, _size, _file, _path FROM s3(s3_conn, filename='03036_archive*.zip :: example2.csv') ORDER BY (id, _file, _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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af80b71 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80746 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000026b20be2 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000026b205f4 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000026b1e405 9. ./contrib/llvm-project/libcxx/include/vector:1472: DB::IObjectStorageIteratorAsync::getCurrentBatchAndScheduleNext() @ 0x0000000026b1f8f8 10. ./contrib/llvm-project/libcxx/include/optional:344: DB::StorageObjectStorageSource::GlobIterator::nextImplUnlocked(unsigned long) @ 0x00000000267e3832 11. ./build_docker/./src/Storages/ObjectStorage/StorageObjectStorageSource.cpp:546: DB::StorageObjectStorageSource::GlobIterator::nextImpl(unsigned long) @ 0x00000000267e30b0 12. ./build_docker/./src/Storages/ObjectStorage/StorageObjectStorageSource.cpp:468: DB::StorageObjectStorageSource::IIterator::next(unsigned long) @ 0x00000000267df498 13. ./build_docker/./src/Storages/ObjectStorage/StorageObjectStorageSource.cpp:0: DB::StorageObjectStorageSource::ArchiveIterator::nextImpl(unsigned long) @ 0x00000000267e97a8 14. ./build_docker/./src/Storages/ObjectStorage/StorageObjectStorageSource.cpp:468: DB::StorageObjectStorageSource::IIterator::next(unsigned long) @ 0x00000000267df498 15. ./build_docker/./src/Storages/ObjectStorage/ReadBufferIterator.cpp:0: DB::ReadBufferIterator::next() @ 0x00000000267ca4ee 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:295: DB::readSchemaFromFormatImpl(std::optional, std::optional const&, DB::IReadBufferIterator&, std::shared_ptr const&) @ 0x000000002d2bcb1e 17. ./build_docker/./src/Formats/ReadSchemaUtils.cpp:0: DB::readSchemaFromFormat(String const&, std::optional const&, DB::IReadBufferIterator&, std::shared_ptr const&) @ 0x000000002d2c4e9b 18. ./build_docker/./src/Storages/ObjectStorage/StorageObjectStorage.cpp:409: DB::StorageObjectStorage::resolveSchemaFromData(std::shared_ptr const&, std::shared_ptr const&, std::optional const&, String&, std::shared_ptr const&) @ 0x00000000267bbe5d 19. ./build_docker/./src/Storages/ObjectStorage/Utils.cpp:0: DB::resolveSchemaAndFormat(DB::ColumnsDescription&, String&, std::shared_ptr, std::shared_ptr const&, std::optional, String&, std::shared_ptr const&) @ 0x000000002681ccea 20. ./build_docker/./src/Storages/ObjectStorage/StorageObjectStorage.cpp:86: DB::StorageObjectStorage::StorageObjectStorage(std::shared_ptr, std::shared_ptr, std::shared_ptr, DB::StorageID const&, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, String const&, std::optional, bool, std::shared_ptr) @ 0x00000000267b59c3 21. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:35: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:v15007]&, std::shared_ptr, std::shared_ptr&, DB::StorageID, DB::ColumnsDescription&, DB::ConstraintsDescription, String, std::nullopt_t const&, bool, std::nullptr_t>(std::allocator, std::shared_ptr&, std::shared_ptr&&, std::shared_ptr&, DB::StorageID&&, DB::ColumnsDescription&, DB::ConstraintsDescription&&, String&&, std::nullopt_t const&, bool&&, std::nullptr_t&&) @ 0x00000000260808fa 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:1460: std::shared_ptr std::allocate_shared[abi:v15007], std::shared_ptr&, std::shared_ptr, std::shared_ptr&, DB::StorageID, DB::ColumnsDescription&, DB::ConstraintsDescription, String, std::nullopt_t const&, bool, std::nullptr_t, void>(std::allocator const&, std::shared_ptr&, std::shared_ptr&&, std::shared_ptr&, DB::StorageID&&, DB::ColumnsDescription&, DB::ConstraintsDescription&&, String&&, std::nullopt_t const&, bool&&, std::nullptr_t&&) @ 0x00000000260803a0 23. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:962: DB::TableFunctionObjectStorage::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x000000002605f267 24. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x00000000265c241e 25. ./build_docker/./src/Interpreters/Context.cpp:2234: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000285361d2 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4819: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000002837024e 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000283ba404 28. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002835ad09 29. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000028359104 30. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000028357f0d 31. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002921bdcc 2025.09.09 15:00:42.729576 [ 4023 ] {9a0e57f5-07fa-4d20-9dd9-f6f7852e4af9} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=0, jobs=0): The table structure cannot be extracted from a CSV format file. You can specify the structure manually. (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af80b71 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80746 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000026b20be2 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000026b205f4 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000026b1e405 9. ./contrib/llvm-project/libcxx/include/vector:1472: DB::IObjectStorageIteratorAsync::getCurrentBatchAndScheduleNext() @ 0x0000000026b1f8f8 10. ./contrib/llvm-project/libcxx/include/optional:344: DB::StorageObjectStorageSource::GlobIterator::nextImplUnlocked(unsigned long) @ 0x00000000267e3832 11. ./build_docker/./src/Storages/ObjectStorage/StorageObjectStorageSource.cpp:546: DB::StorageObjectStorageSource::GlobIterator::nextImpl(unsigned long) @ 0x00000000267e30b0 12. ./build_docker/./src/Storages/ObjectStorage/StorageObjectStorageSource.cpp:468: DB::StorageObjectStorageSource::IIterator::next(unsigned long) @ 0x00000000267df498 13. ./build_docker/./src/Storages/ObjectStorage/StorageObjectStorageSource.cpp:0: DB::StorageObjectStorageSource::ArchiveIterator::nextImpl(unsigned long) @ 0x00000000267e97a8 14. ./build_docker/./src/Storages/ObjectStorage/StorageObjectStorageSource.cpp:468: DB::StorageObjectStorageSource::IIterator::next(unsigned long) @ 0x00000000267df498 15. ./build_docker/./src/Storages/ObjectStorage/ReadBufferIterator.cpp:0: DB::ReadBufferIterator::next() @ 0x00000000267ca4ee 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:295: DB::readSchemaFromFormatImpl(std::optional, std::optional const&, DB::IReadBufferIterator&, std::shared_ptr const&) @ 0x000000002d2bcb1e 17. ./build_docker/./src/Formats/ReadSchemaUtils.cpp:0: DB::readSchemaFromFormat(String const&, std::optional const&, DB::IReadBufferIterator&, std::shared_ptr const&) @ 0x000000002d2c4e9b 18. ./build_docker/./src/Storages/ObjectStorage/StorageObjectStorage.cpp:409: DB::StorageObjectStorage::resolveSchemaFromData(std::shared_ptr const&, std::shared_ptr const&, std::optional const&, String&, std::shared_ptr const&) @ 0x00000000267bbe5d 19. ./build_docker/./src/Storages/ObjectStorage/Utils.cpp:0: DB::resolveSchemaAndFormat(DB::ColumnsDescription&, String&, std::shared_ptr, std::shared_ptr const&, std::optional, String&, std::shared_ptr const&) @ 0x000000002681ccea 20. ./build_docker/./src/Storages/ObjectStorage/StorageObjectStorage.cpp:86: DB::StorageObjectStorage::StorageObjectStorage(std::shared_ptr, std::shared_ptr, std::shared_ptr, DB::StorageID const&, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, String const&, std::optional, bool, std::shared_ptr) @ 0x00000000267b59c3 21. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:35: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:v15007]&, std::shared_ptr, std::shared_ptr&, DB::StorageID, DB::ColumnsDescription&, DB::ConstraintsDescription, String, std::nullopt_t const&, bool, std::nullptr_t>(std::allocator, std::shared_ptr&, std::shared_ptr&&, std::shared_ptr&, DB::StorageID&&, DB::ColumnsDescription&, DB::ConstraintsDescription&&, String&&, std::nullopt_t const&, bool&&, std::nullptr_t&&) @ 0x00000000260808fa 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:1460: std::shared_ptr std::allocate_shared[abi:v15007], std::shared_ptr&, std::shared_ptr, std::shared_ptr&, DB::StorageID, DB::ColumnsDescription&, DB::ConstraintsDescription, String, std::nullopt_t const&, bool, std::nullptr_t, void>(std::allocator const&, std::shared_ptr&, std::shared_ptr&&, std::shared_ptr&, DB::StorageID&&, DB::ColumnsDescription&, DB::ConstraintsDescription&&, String&&, std::nullopt_t const&, bool&&, std::nullptr_t&&) @ 0x00000000260803a0 23. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:962: DB::TableFunctionObjectStorage::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x000000002605f267 24. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x00000000265c241e 25. ./build_docker/./src/Interpreters/Context.cpp:2234: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000285361d2 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4819: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000002837024e 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000283ba404 28. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002835ad09 29. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000028359104 30. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000028357f0d 31. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002921bdcc 2025.09.09 15:00:42.887477 [ 4023 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 15:00:43.395283 [ 2839 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:00:43.395622 [ 2850 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:00:43.915778 [ 4023 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 15:00:44.397669 [ 2857 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:00:44.398025 [ 2861 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:00:44.859658 [ 3612 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 15:00:45.400155 [ 2875 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:00:45.400637 [ 2876 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:00:45.903368 [ 4023 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 15:00:46.402481 [ 2896 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:00:46.402829 [ 2890 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:00:46.879688 [ 3612 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 15:00:47.404815 [ 2917 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:00:47.405271 [ 2902 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:00:47.908902 [ 4023 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 15:00:48.406973 [ 2933 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:00:48.407564 [ 2932 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:00:48.890466 [ 3612 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 15:00:49.409066 [ 2950 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:00:49.414946 [ 2949 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:00:49.859789 [ 4023 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 15:00:50.411315 [ 2972 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:00:50.417224 [ 2965 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:00:50.779646 [ 3612 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 15:00:51.131223 [ 4023 ] {35dd6820-fa6e-4b85-a7ac-0cd2c290512a} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=773, jobs=735). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:37454) (in query: SELECT arrayRandomSample([1,2,3], 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af872f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af7b2d1 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af7c3f3 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d36920d 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000002d369e5f 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processOrdinaryQuery() @ 0x000000002d18af7b 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d17644a 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 15. asan_thread_start(void*) @ 0x000000000aa43059 16. ? @ 0x00007f35aab92ac3 17. ? @ 0x00007f35aac24850 2025.09.09 15:00:51.132604 [ 4023 ] {35dd6820-fa6e-4b85-a7ac-0cd2c290512a} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=773, 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af872f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af7b2d1 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af7c3f3 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d36920d 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000002d369e5f 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processOrdinaryQuery() @ 0x000000002d18af7b 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d17644a 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 15. asan_thread_start(void*) @ 0x000000000aa43059 16. ? @ 0x00007f35aab92ac3 17. ? @ 0x00007f35aac24850 2025.09.09 15:00:51.413693 [ 2982 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:00:51.419546 [ 2985 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:00:51.788137 [ 4023 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 15:00:52.416173 [ 3004 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:00:52.421762 [ 3008 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:00:52.883938 [ 4023 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 15:00:53.418764 [ 3013 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:00:53.424087 [ 3026 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:00:53.983145 [ 4023 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 15:00:54.421074 [ 3035 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:00:54.426116 [ 3028 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:00:54.996960 [ 4023 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 15:00:55.423382 [ 3048 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:00:55.428106 [ 3045 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:00:55.931484 [ 4023 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 15:00:56.425286 [ 3066 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:00:56.430008 [ 3067 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:00:56.962285 [ 3612 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 15:00:57.238438 [ 13328 ] {} DynamicQueryHandler: Code: 452. DB::Exception: Setting max_execution_time shouldn't be greater than 60. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x0000000026f841fa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:368: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f81de0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/find_if.h:25: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f808a4 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000002d065739 10. ./build_docker/./src/Server/HTTPHandler.cpp:705: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000002d06d139 11. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000002d1cc337 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 15. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 16. asan_thread_start(void*) @ 0x000000000aa43059 17. ? @ 0x00007f35aab92ac3 18. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:00:57.427353 [ 3084 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:00:57.432045 [ 3087 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:00:57.946331 [ 4023 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 15:00:58.429543 [ 3106 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:00:58.434369 [ 3105 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:00:58.865183 [ 4023 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 15:00:59.376041 [ 4023 ] {9e118a4f-f216-4783-a851-3bad6043ef0b} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 2nd argument 'samples' to function 'arrayRandomSample'. Expected: const UInt*, got: Int8: In scope SELECT arrayRandomSample([1, 2, 3], -5). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:37558) (in query: SELECT arrayRandomSample([1, 2, 3], -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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 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&&) @ 0x000000000aaec6f5 4. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000000aae6b1a 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000000aae5e2a 6. DB::FunctionArrayRandomSample::getReturnTypeImpl(std::vector> const&) const @ 0x000000001a31fecd 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000ccd376e 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000ccd3176 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000ccd4343 10. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000028399ff0 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000028367bce 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028366290 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283b62c9 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002835ae03 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000028359104 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000028357f0d 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002921bdcc 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&) @ 0x000000002941f313 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&) @ 0x0000000029419aef 20. ./contrib/llvm-project/libcxx/include/vector:432: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000029421f5d 21. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000029344c1b 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*) @ 0x0000000029b3703b 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 25. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 29. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 30. asan_thread_start(void*) @ 0x000000000aa43059 31. ? @ 0x00007f35aab92ac3 2025.09.09 15:00:59.378354 [ 4023 ] {9e118a4f-f216-4783-a851-3bad6043ef0b} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 2nd argument 'samples' to function 'arrayRandomSample'. Expected: const UInt*, got: Int8: In scope SELECT arrayRandomSample([1, 2, 3], -5). (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 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&&) @ 0x000000000aaec6f5 4. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000000aae6b1a 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000000aae5e2a 6. DB::FunctionArrayRandomSample::getReturnTypeImpl(std::vector> const&) const @ 0x000000001a31fecd 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000ccd376e 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000ccd3176 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000ccd4343 10. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000028399ff0 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000028367bce 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028366290 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283b62c9 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002835ae03 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000028359104 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000028357f0d 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002921bdcc 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&) @ 0x000000002941f313 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&) @ 0x0000000029419aef 20. ./contrib/llvm-project/libcxx/include/vector:432: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000029421f5d 21. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000029344c1b 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*) @ 0x0000000029b3703b 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 25. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 29. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 30. asan_thread_start(void*) @ 0x000000000aa43059 31. ? @ 0x00007f35aab92ac3 2025.09.09 15:00:59.431827 [ 3112 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:00:59.436465 [ 3114 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:00:59.595857 [ 4023 ] {5b5f49c0-e8f1-4656-ab9f-7b50a475e897} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 2nd argument 'samples' to function 'arrayRandomSample'. Expected: const UInt*, got: String: In scope SELECT arrayRandomSample([1, 2, 3], 'a'). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:37570) (in query: SELECT arrayRandomSample([1, 2, 3], '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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 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&&) @ 0x000000000aaec6f5 4. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000000aae6b1a 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000000aae5e2a 6. DB::FunctionArrayRandomSample::getReturnTypeImpl(std::vector> const&) const @ 0x000000001a31fecd 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000ccd376e 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000ccd3176 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000ccd4343 10. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000028399ff0 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000028367bce 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028366290 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283b62c9 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002835ae03 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000028359104 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000028357f0d 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002921bdcc 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&) @ 0x000000002941f313 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&) @ 0x0000000029419aef 20. ./contrib/llvm-project/libcxx/include/vector:432: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000029421f5d 21. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000029344c1b 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*) @ 0x0000000029b3703b 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 25. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 29. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 30. asan_thread_start(void*) @ 0x000000000aa43059 31. ? @ 0x00007f35aab92ac3 2025.09.09 15:00:59.598513 [ 4023 ] {5b5f49c0-e8f1-4656-ab9f-7b50a475e897} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 2nd argument 'samples' to function 'arrayRandomSample'. Expected: const UInt*, got: String: In scope SELECT arrayRandomSample([1, 2, 3], 'a'). (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 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&&) @ 0x000000000aaec6f5 4. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000000aae6b1a 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000000aae5e2a 6. DB::FunctionArrayRandomSample::getReturnTypeImpl(std::vector> const&) const @ 0x000000001a31fecd 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000ccd376e 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000ccd3176 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000ccd4343 10. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000028399ff0 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000028367bce 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028366290 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283b62c9 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002835ae03 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000028359104 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000028357f0d 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002921bdcc 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&) @ 0x000000002941f313 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&) @ 0x0000000029419aef 20. ./contrib/llvm-project/libcxx/include/vector:432: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000029421f5d 21. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000029344c1b 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*) @ 0x0000000029b3703b 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 25. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 29. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 30. asan_thread_start(void*) @ 0x000000000aa43059 31. ? @ 0x00007f35aab92ac3 2025.09.09 15:00:59.795386 [ 3612 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 15:00:59.806971 [ 4023 ] {034a0d93-6dba-476c-8662-e87fdb277c27} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 2nd argument 'samples' to function 'arrayRandomSample'. Expected: const UInt*, got: Float64: In scope SELECT arrayRandomSample([1, 2, 3], 1.5). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:37582) (in query: SELECT arrayRandomSample([1, 2, 3], 1.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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 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&&) @ 0x000000000aaec6f5 4. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000000aae6b1a 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000000aae5e2a 6. DB::FunctionArrayRandomSample::getReturnTypeImpl(std::vector> const&) const @ 0x000000001a31fecd 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000ccd376e 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000ccd3176 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000ccd4343 10. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000028399ff0 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000028367bce 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028366290 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283b62c9 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002835ae03 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000028359104 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000028357f0d 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002921bdcc 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&) @ 0x000000002941f313 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&) @ 0x0000000029419aef 20. ./contrib/llvm-project/libcxx/include/vector:432: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000029421f5d 21. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000029344c1b 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*) @ 0x0000000029b3703b 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 25. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 29. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 30. asan_thread_start(void*) @ 0x000000000aa43059 31. ? @ 0x00007f35aab92ac3 2025.09.09 15:00:59.829673 [ 4023 ] {034a0d93-6dba-476c-8662-e87fdb277c27} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 2nd argument 'samples' to function 'arrayRandomSample'. Expected: const UInt*, got: Float64: In scope SELECT arrayRandomSample([1, 2, 3], 1.5). (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 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&&) @ 0x000000000aaec6f5 4. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000000aae6b1a 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000000aae5e2a 6. DB::FunctionArrayRandomSample::getReturnTypeImpl(std::vector> const&) const @ 0x000000001a31fecd 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000ccd376e 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000ccd3176 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000ccd4343 10. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000028399ff0 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000028367bce 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028366290 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283b62c9 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002835ae03 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000028359104 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000028357f0d 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002921bdcc 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&) @ 0x000000002941f313 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&) @ 0x0000000029419aef 20. ./contrib/llvm-project/libcxx/include/vector:432: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000029421f5d 21. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000029344c1b 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*) @ 0x0000000029b3703b 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 25. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 29. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 30. asan_thread_start(void*) @ 0x000000000aa43059 31. ? @ 0x00007f35aab92ac3 2025.09.09 15:01:00.434160 [ 3123 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:01:00.438525 [ 3129 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:01:00.750764 [ 3612 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 15:01:01.437260 [ 3139 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:01:01.441848 [ 3142 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:01:02.049849 [ 4023 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 15:01:02.439493 [ 3172 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:01:02.444409 [ 3167 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:01:03.031834 [ 4023 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 15:01:03.441502 [ 3186 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:01:03.446695 [ 3183 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:01:03.976124 [ 4023 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 15:01:04.444569 [ 3206 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:01:04.449231 [ 3204 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:01:04.933895 [ 3612 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 15:01:05.024190 [ 4023 ] {495b58bd-1e94-40ac-a61f-1484ae082a5a} executeQuery: Code: 497. DB::Exception: user_test_02337: Not enough privileges. To execute this query, it's necessary to have the grant SYSTEM DROP FILESYSTEM CACHE ON *.*. (ACCESS_DENIED) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:37646) (comment: 02337_drop_filesystem_cache_access.sh) (in query: SYSTEM DROP 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: auto bool DB::ContextAccess::checkAccessImplHelper(std::shared_ptr const&, DB::AccessFlags) const::'lambda'(int, FormatStringHelperImpl::type...>, $T&&...)::operator()(int, FormatStringHelperImpl::type...>, $T&&...) const @ 0x0000000026dc1d50 4. ./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 @ 0x0000000026dc173d 5. ./build_docker/./src/Access/ContextAccess.cpp:687: bool DB::ContextAccess::checkAccessImplHelper(std::shared_ptr const&, DB::AccessFlags) const @ 0x0000000026dc0353 6. ./build_docker/./src/Access/ContextAccess.cpp:823: DB::ContextAccess::checkAccess(std::shared_ptr const&, DB::AccessFlags const&) const @ 0x0000000026d93c65 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkAccess(DB::AccessFlags const&) const @ 0x0000000028527484 8. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:0: DB::InterpreterSystemQuery::execute() @ 0x0000000029b989ab 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b382fc 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 15:01:05.027193 [ 4023 ] {495b58bd-1e94-40ac-a61f-1484ae082a5a} TCPHandler: Code: 497. DB::Exception: user_test_02337: Not enough privileges. To execute this query, it's necessary to have the grant SYSTEM DROP FILESYSTEM CACHE 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: auto bool DB::ContextAccess::checkAccessImplHelper(std::shared_ptr const&, DB::AccessFlags) const::'lambda'(int, FormatStringHelperImpl::type...>, $T&&...)::operator()(int, FormatStringHelperImpl::type...>, $T&&...) const @ 0x0000000026dc1d50 4. ./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 @ 0x0000000026dc173d 5. ./build_docker/./src/Access/ContextAccess.cpp:687: bool DB::ContextAccess::checkAccessImplHelper(std::shared_ptr const&, DB::AccessFlags) const @ 0x0000000026dc0353 6. ./build_docker/./src/Access/ContextAccess.cpp:823: DB::ContextAccess::checkAccess(std::shared_ptr const&, DB::AccessFlags const&) const @ 0x0000000026d93c65 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkAccess(DB::AccessFlags const&) const @ 0x0000000028527484 8. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:0: DB::InterpreterSystemQuery::execute() @ 0x0000000029b989ab 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b382fc 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 15:01:05.446632 [ 3230 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:01:05.451218 [ 3223 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:01:05.848625 [ 4023 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 15:01:06.449031 [ 3234 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:01:06.453238 [ 3232 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:01:06.841261 [ 3612 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 15:01:07.451377 [ 2737 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:01:07.455286 [ 2736 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:01:07.769725 [ 3612 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 15:01:08.464379 [ 2759 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:01:08.464413 [ 2760 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:01:08.855731 [ 3612 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 15:01:09.551690 [ 2769 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:01:09.551744 [ 2777 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:01:09.865527 [ 3612 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 15:01:10.554136 [ 2791 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:01:10.554632 [ 2797 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:01:10.886519 [ 3612 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 15:01:11.556383 [ 2813 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:01:11.556753 [ 2818 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:01:11.859623 [ 3612 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 15:01:12.567502 [ 2827 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:01:12.589073 [ 2834 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:01:12.860519 [ 3612 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 15:01:13.570096 [ 2851 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:01:13.592844 [ 2849 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:01:13.841177 [ 4025 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 15:01:14.572292 [ 2866 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:01:14.595498 [ 2872 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:01:14.824778 [ 4025 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 15:01:15.574546 [ 2881 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:01:15.595730 [ 13328 ] {} DynamicQueryHandler: Code: 452. DB::Exception: Setting max_execution_time shouldn't be greater than 60. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x0000000026f841fa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:368: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f81de0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/find_if.h:25: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f808a4 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000002d065739 10. ./build_docker/./src/Server/HTTPHandler.cpp:705: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000002d06d139 11. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000002d1cc337 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 15. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 16. asan_thread_start(void*) @ 0x000000000aa43059 17. ? @ 0x00007f35aab92ac3 18. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:01:15.598359 [ 2880 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:01:15.778399 [ 3612 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 15:01:16.576456 [ 2892 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:01:16.601189 [ 2890 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:01:16.921818 [ 3612 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 15:01:17.225052 [ 3327 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {8dd55f4d-4394-4634-a445-9c7c9e0f4148::202509_1_102_58}: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=13, jobs=0). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af80b71 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80746 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002c765aab 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:1197: ? @ 0x000000002c7602b8 8. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x000000002c75fc2b 9. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:0: DB::MergeTreeReaderCompact::MergeTreeReaderCompact(std::shared_ptr, DB::NamesAndTypesList, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*, DB::MarkCache*, DB::MarkRanges, DB::MergeTreeReaderSettings, std::map, std::allocator>>, std::function const&, int) @ 0x000000002c7aee03 10. ./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.h:16: DB::MergeTreeReaderCompactSingleBuffer::MergeTreeReaderCompactSingleBuffer&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int&&) @ 0x000000002c5d6d21 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::MergeTreeDataPartCompact::getReader(DB::NamesAndTypesList const&, std::shared_ptr const&, DB::MarkRanges const&, std::unordered_map, std::equal_to, std::allocator>> const&, DB::UncompressedCache*, DB::MarkCache*, std::shared_ptr const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) const @ 0x000000002c5d1037 12. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:169: DB::MergeTreeSequentialSource::MergeTreeSequentialSource(DB::MergeTreeSequentialSourceType, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::vector>, std::optional, bool, bool, bool) @ 0x000000002c80c330 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:35: DB::MergeTreeSequentialSource* std::construct_at[abi:v15007] const&, std::shared_ptr&, std::shared_ptr&, std::vector>&, std::optional, bool, bool&, bool&, DB::MergeTreeSequentialSource*>(DB::MergeTreeSequentialSource*, DB::MergeTreeSequentialSourceType&, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr&, std::shared_ptr&, std::vector>&, std::optional&&, bool&&, bool&, bool&) @ 0x000000002c81320f 14. ./contrib/llvm-project/libcxx/include/__memory/allocator_traits.h:298: DB::createMergeTreeSequentialSource(DB::MergeTreeSequentialSourceType, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::vector>, std::optional, std::shared_ptr>, bool, bool, bool) @ 0x000000002c810812 15. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1136: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::createMergedStream() @ 0x000000002c3dd079 16. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() @ 0x000000002c3d6516 17. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:534: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x000000002c3e2799 18. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::execute() @ 0x000000002c3ef3fe 19. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:0: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000002cc2f4c0 20. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000002c427f28 21. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000002c429675 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7eaf0 23. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001af8a79f 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 26. asan_thread_start(void*) @ 0x000000000aa43059 27. ? @ 0x00007f35aab92ac3 28. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:01:17.578955 [ 2918 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:01:17.603259 [ 2920 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:01:18.014339 [ 4025 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 15:01:18.581297 [ 2934 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:01:18.605371 [ 2933 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:01:19.048586 [ 3612 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 15:01:19.584751 [ 2950 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:01:19.634104 [ 2949 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:01:20.044228 [ 3612 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 15:01:20.074475 [ 3341 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {106d09da-5a03-4cbf-a443-a9d7490e42ad::202509_1_96_19}: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=13, jobs=0). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af80b71 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80746 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002c765aab 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:1197: ? @ 0x000000002c7602b8 8. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x000000002c75fc2b 9. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:0: DB::MergeTreeReaderCompact::MergeTreeReaderCompact(std::shared_ptr, DB::NamesAndTypesList, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*, DB::MarkCache*, DB::MarkRanges, DB::MergeTreeReaderSettings, std::map, std::allocator>>, std::function const&, int) @ 0x000000002c7aee03 10. ./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.h:16: DB::MergeTreeReaderCompactSingleBuffer::MergeTreeReaderCompactSingleBuffer&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int&&) @ 0x000000002c5d6d21 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::MergeTreeDataPartCompact::getReader(DB::NamesAndTypesList const&, std::shared_ptr const&, DB::MarkRanges const&, std::unordered_map, std::equal_to, std::allocator>> const&, DB::UncompressedCache*, DB::MarkCache*, std::shared_ptr const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) const @ 0x000000002c5d1037 12. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:169: DB::MergeTreeSequentialSource::MergeTreeSequentialSource(DB::MergeTreeSequentialSourceType, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::vector>, std::optional, bool, bool, bool) @ 0x000000002c80c330 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:35: DB::MergeTreeSequentialSource* std::construct_at[abi:v15007] const&, std::shared_ptr&, std::shared_ptr&, std::vector>&, std::optional, bool, bool&, bool&, DB::MergeTreeSequentialSource*>(DB::MergeTreeSequentialSource*, DB::MergeTreeSequentialSourceType&, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr&, std::shared_ptr&, std::vector>&, std::optional&&, bool&&, bool&, bool&) @ 0x000000002c81320f 14. ./contrib/llvm-project/libcxx/include/__memory/allocator_traits.h:298: DB::createMergeTreeSequentialSource(DB::MergeTreeSequentialSourceType, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::vector>, std::optional, std::shared_ptr>, bool, bool, bool) @ 0x000000002c810812 15. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1136: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::createMergedStream() @ 0x000000002c3dd079 16. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() @ 0x000000002c3d6516 17. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:534: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x000000002c3e2799 18. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::execute() @ 0x000000002c3ef3fe 19. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:0: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000002cc2f4c0 20. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000002c427f28 21. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000002c429675 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7eaf0 23. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001af8a79f 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 26. asan_thread_start(void*) @ 0x000000000aa43059 27. ? @ 0x00007f35aab92ac3 28. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:01:20.588176 [ 2969 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:01:20.637982 [ 2975 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:01:21.123391 [ 3612 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 15:01:21.592144 [ 2983 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:01:21.641382 [ 2977 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:01:22.302753 [ 3612 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 15:01:22.594726 [ 3007 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:01:22.643641 [ 3006 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:01:23.325882 [ 3612 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 15:01:23.597322 [ 3014 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:01:23.646388 [ 3025 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:01:24.362148 [ 3612 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 15:01:24.599476 [ 3038 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:01:24.648577 [ 3042 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:01:25.402051 [ 3604 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 15:01:25.602276 [ 3059 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:01:25.657215 [ 3057 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:01:26.419292 [ 3604 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 15:01:26.608617 [ 3076 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:01:26.659640 [ 3082 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:01:27.464765 [ 3604 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 15:01:27.611364 [ 3103 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:01:27.662242 [ 3106 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:01:28.566837 [ 3612 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 15:01:28.614415 [ 3112 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:01:28.667570 [ 3117 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:01:29.616897 [ 3129 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:01:29.670116 [ 3133 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:01:30.190608 [ 3604 ] {b0cabbea-da4e-4ca3-be70-4a61988336d4} executeQuery: Code: 48. DB::Exception: Current join algorithm is supported only for pipelines without totals. (NOT_IMPLEMENTED) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:44690) (comment: 02932_non_ready_set_stuck.sql) (in query: SELECT * FROM (SELECT item_id FROM tab GROUP BY item_id WITH TOTALS ORDER BY '922337203.6854775806' IN (SELECT NULL)) AS l RIGHT JOIN (SELECT item_id FROM tab) AS r ON l.item_id = r.item_id WHERE NULL;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aac868e 4. ./build_docker/./src/QueryPipeline/QueryPipelineBuilder.cpp:368: DB::QueryPipelineBuilder::joinPipelinesYShaped(std::unique_ptr>, std::unique_ptr>, std::shared_ptr, DB::Block const&, unsigned long, std::vector, std::allocator>>*) @ 0x000000002783e552 5. ./build_docker/./src/Processors/QueryPlan/JoinStep.cpp:60: DB::JoinStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000002ddd4d41 6. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000002ddff11e 7. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000002942117f 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x00000000294209e7 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b382fc 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 15:01:30.210334 [ 3604 ] {b0cabbea-da4e-4ca3-be70-4a61988336d4} TCPHandler: Code: 48. DB::Exception: Current join algorithm is supported only for pipelines without totals. (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aac868e 4. ./build_docker/./src/QueryPipeline/QueryPipelineBuilder.cpp:368: DB::QueryPipelineBuilder::joinPipelinesYShaped(std::unique_ptr>, std::unique_ptr>, std::shared_ptr, DB::Block const&, unsigned long, std::vector, std::allocator>>*) @ 0x000000002783e552 5. ./build_docker/./src/Processors/QueryPlan/JoinStep.cpp:60: DB::JoinStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000002ddd4d41 6. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000002ddff11e 7. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000002942117f 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x00000000294209e7 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b382fc 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 15:01:30.619704 [ 3128 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:01:30.673125 [ 3150 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:01:31.573495 [ 3163 ] {} DatabaseCatalog: Cannot drop tables. Will retry later.: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=0, jobs=0). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af819ed 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80746 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000263a174e 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000286c6b9c 8. ./contrib/llvm-project/libcxx/include/vector:590: DB::DatabaseCatalog::dropTableDataTask() @ 0x00000000286c7466 9. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 11. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 14. asan_thread_start(void*) @ 0x000000000aa43059 15. ? @ 0x00007f35aab92ac3 16. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:01:31.623130 [ 3149 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:01:31.676077 [ 3156 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:01:32.625682 [ 3186 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:01:32.678812 [ 3183 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:01:33.055596 [ 3604 ] {cddb1e18-e882-4879-8cf3-ddd89ff68631} executeQuery: Code: 48. DB::Exception: Truncate is not supported by storage Null. (NOT_IMPLEMENTED) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:44704) (comment: 01836_date_time_keep_default_timezone_on_operations_den_crane.sql) (in query: DROP TABLE tt_null;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::IStorage::truncate(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, DB::TableExclusiveLockHolder&) @ 0x00000000260e9270 4. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:279: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x00000000291f066f 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x00000000291ed665 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x00000000291ebd68 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x00000000291eb7ed 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b382fc 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 11. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 15. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 16. asan_thread_start(void*) @ 0x000000000aa43059 17. ? @ 0x00007f35aab92ac3 18. ? @ 0x00007f35aac24850 2025.09.09 15:01:33.069459 [ 3604 ] {cddb1e18-e882-4879-8cf3-ddd89ff68631} 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::IStorage::truncate(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, DB::TableExclusiveLockHolder&) @ 0x00000000260e9270 4. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:279: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x00000000291f066f 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x00000000291ed665 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x00000000291ebd68 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x00000000291eb7ed 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b382fc 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 11. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 15. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 16. asan_thread_start(void*) @ 0x000000000aa43059 17. ? @ 0x00007f35aab92ac3 18. ? @ 0x00007f35aac24850 2025.09.09 15:01:33.627852 [ 3197 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:01:33.680851 [ 3203 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:01:34.629996 [ 3215 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:01:34.683192 [ 3223 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:01:35.632278 [ 3240 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:01:35.686136 [ 3243 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:01:36.634166 [ 2743 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:01:36.688372 [ 2752 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:01:37.637509 [ 2776 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:01:37.698570 [ 2780 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:01:38.640234 [ 2804 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:01:38.701891 [ 2824 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:01:39.277762 [ 3328 ] {} 3142ca00-8f52-4485-ac64-079835a6dda7::all_0_0_0_1 (MutateFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=6, jobs=6). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af80b71 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80746 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d34b5ca 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000002d3486e4 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000002d34827b 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002d36bcf7 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 12. asan_thread_start(void*) @ 0x000000000aa43059 13. ? @ 0x00007f35aab92ac3 14. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:01:39.288987 [ 3328 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {3142ca00-8f52-4485-ac64-079835a6dda7::all_0_0_0_1}: 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af80b71 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80746 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d34b5ca 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000002d3486e4 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000002d34827b 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002d36bcf7 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 12. asan_thread_start(void*) @ 0x000000000aa43059 13. ? @ 0x00007f35aab92ac3 14. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:01:39.650801 [ 2852 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:01:39.704092 [ 2855 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:01:40.188467 [ 3604 ] {2bf5aced-bb01-4301-acc6-5bd51f60d838} executeQuery: Code: 57. DB::Exception: Table test_15.nested already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:33506) (comment: 00554_nested_and_table_engines.sql) (in query: CREATE TABLE nested (x UInt8, n Nested(a UInt64, b 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa91e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1558: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291bc5ff 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291ac835 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000291c3415 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b382fc 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 15. asan_thread_start(void*) @ 0x000000000aa43059 16. ? @ 0x00007f35aab92ac3 17. ? @ 0x00007f35aac24850 2025.09.09 15:01:40.195308 [ 3604 ] {2bf5aced-bb01-4301-acc6-5bd51f60d838} TCPHandler: Code: 57. DB::Exception: Table test_15.nested already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa91e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1558: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291bc5ff 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291ac835 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000291c3415 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b382fc 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 15. asan_thread_start(void*) @ 0x000000000aa43059 16. ? @ 0x00007f35aab92ac3 17. ? @ 0x00007f35aac24850 2025.09.09 15:01:40.418260 [ 3333 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {ccc63915-230c-46e1-a015-6f55b3fb64ee::202509_1_111_22}: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=13, 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af80b71 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80746 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002c765aab 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:1197: ? @ 0x000000002c7602b8 8. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x000000002c75fc2b 9. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:0: DB::MergeTreeReaderCompact::MergeTreeReaderCompact(std::shared_ptr, DB::NamesAndTypesList, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*, DB::MarkCache*, DB::MarkRanges, DB::MergeTreeReaderSettings, std::map, std::allocator>>, std::function const&, int) @ 0x000000002c7aee03 10. ./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.h:16: DB::MergeTreeReaderCompactSingleBuffer::MergeTreeReaderCompactSingleBuffer&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int&&) @ 0x000000002c5d6d21 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::MergeTreeDataPartCompact::getReader(DB::NamesAndTypesList const&, std::shared_ptr const&, DB::MarkRanges const&, std::unordered_map, std::equal_to, std::allocator>> const&, DB::UncompressedCache*, DB::MarkCache*, std::shared_ptr const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) const @ 0x000000002c5d1037 12. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:169: DB::MergeTreeSequentialSource::MergeTreeSequentialSource(DB::MergeTreeSequentialSourceType, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::vector>, std::optional, bool, bool, bool) @ 0x000000002c80c330 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:35: DB::MergeTreeSequentialSource* std::construct_at[abi:v15007] const&, std::shared_ptr&, std::shared_ptr&, std::vector>&, std::optional, bool, bool&, bool&, DB::MergeTreeSequentialSource*>(DB::MergeTreeSequentialSource*, DB::MergeTreeSequentialSourceType&, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr&, std::shared_ptr&, std::vector>&, std::optional&&, bool&&, bool&, bool&) @ 0x000000002c81320f 14. ./contrib/llvm-project/libcxx/include/__memory/allocator_traits.h:298: DB::createMergeTreeSequentialSource(DB::MergeTreeSequentialSourceType, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::vector>, std::optional, std::shared_ptr>, bool, bool, bool) @ 0x000000002c810812 15. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1136: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::createMergedStream() @ 0x000000002c3dd079 16. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() @ 0x000000002c3d6516 17. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:534: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x000000002c3e2799 18. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::execute() @ 0x000000002c3ef3fe 19. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:0: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000002cc2f4c0 20. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000002c427f28 21. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000002c429675 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7eaf0 23. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001af8a79f 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 26. asan_thread_start(void*) @ 0x000000000aa43059 27. ? @ 0x00007f35aab92ac3 28. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:01:40.462006 [ 3326 ] {} 3142ca00-8f52-4485-ac64-079835a6dda7::all_0_0_0_1 (MutateFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=6, jobs=6). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af819ed 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80746 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d34b5ca 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000002d3486e4 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000002d34827b 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002d36bcf7 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 12. asan_thread_start(void*) @ 0x000000000aa43059 13. ? @ 0x00007f35aab92ac3 14. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:01:40.463439 [ 3326 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {3142ca00-8f52-4485-ac64-079835a6dda7::all_0_0_0_1}: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=6, jobs=6). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af819ed 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80746 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d34b5ca 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000002d3486e4 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000002d34827b 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002d36bcf7 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 12. asan_thread_start(void*) @ 0x000000000aa43059 13. ? @ 0x00007f35aab92ac3 14. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:01:40.652726 [ 2893 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:01:40.705690 [ 2887 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:01:40.810528 [ 3604 ] {364a6737-18d2-4f6a-8e68-4499b5c923f6} executeQuery: Code: 36. DB::Exception: Codec Delta is only applicable for data types of size 1, 2, 4, 8 bytes. Given type Decimal(38, 10). (BAD_ARGUMENTS) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:33508) (comment: 01380_coded_delta_exception_code.sql) (in query: CREATE TABLE delta_codec_synthetic (`id` Decimal(38, 10) CODEC(Delta, ZSTD(22))) ENGINE = MergeTree ORDER BY tuple() SETTINGS index_granularity = 45552, min_bytes_for_wide_part = 1073741824, ratio_of_defaults_for_sparse_serialization = 0.09494186192750931, replace_long_file_name_to_hash = false, max_file_name_length = 37, min_bytes_for_full_part_storage = 470025013, compact_parts_max_bytes_to_buffer = 295120540, compact_parts_max_granules_to_buffer = 141, compact_parts_merge_max_bytes_to_prefetch_part = 31699090, merge_max_block_size = 18362, old_parts_lifetime = 19., prefer_fetch_merged_part_size_threshold = 10737418240, vertical_merge_algorithm_min_rows_to_activate = 632661, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 8477081882, index_granularity_bytes = 30147191, concurrent_part_removal_threshold = 100, allow_vertical_merges_from_compact_to_wide_parts = true, cache_populated_by_fetch = true, marks_compress_block_size = 63569, primary_key_compress_block_size = 29258), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000aad4b34 4. ./build_docker/./src/Compression/CompressionCodecDelta.cpp:184: 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*) @ 0x000000002779099d 5. ./build_docker/./src/Compression/CompressionFactoryAdditions.cpp:135: void std::__function::__policy_invoker::__call_impl const&, std::shared_ptr const&, bool, bool, bool, bool) const::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x00000000291e960b 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000027a9e455 7. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:106: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x0000000027a9ea65 8. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:100: DB::CompressionCodecFactory::validateCodecAndGetPreprocessedAST(std::shared_ptr const&, std::shared_ptr const&, bool, bool, bool, bool) const @ 0x00000000291e6e9d 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:699: DB::InterpreterCreateQuery::getColumnsDescription(DB::ASTExpressionList const&, std::shared_ptr, DB::LoadingStrictnessLevel, bool) @ 0x000000002919a3c8 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&, DB::LoadingStrictnessLevel) const @ 0x000000002919cf0e 11. ./src/Parsers/ASTCreateQuery.h:175: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291aa55d 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000291c3415 13. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b382fc 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 16. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 20. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 21. asan_thread_start(void*) @ 0x000000000aa43059 22. ? @ 0x00007f35aab92ac3 23. ? @ 0x00007f35aac24850 2025.09.09 15:01:40.812338 [ 3604 ] {364a6737-18d2-4f6a-8e68-4499b5c923f6} TCPHandler: Code: 36. DB::Exception: Codec Delta is only applicable for data types of size 1, 2, 4, 8 bytes. Given type Decimal(38, 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000aad4b34 4. ./build_docker/./src/Compression/CompressionCodecDelta.cpp:184: 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*) @ 0x000000002779099d 5. ./build_docker/./src/Compression/CompressionFactoryAdditions.cpp:135: void std::__function::__policy_invoker::__call_impl const&, std::shared_ptr const&, bool, bool, bool, bool) const::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x00000000291e960b 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000027a9e455 7. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:106: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x0000000027a9ea65 8. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:100: DB::CompressionCodecFactory::validateCodecAndGetPreprocessedAST(std::shared_ptr const&, std::shared_ptr const&, bool, bool, bool, bool) const @ 0x00000000291e6e9d 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:699: DB::InterpreterCreateQuery::getColumnsDescription(DB::ASTExpressionList const&, std::shared_ptr, DB::LoadingStrictnessLevel, bool) @ 0x000000002919a3c8 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&, DB::LoadingStrictnessLevel) const @ 0x000000002919cf0e 11. ./src/Parsers/ASTCreateQuery.h:175: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291aa55d 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000291c3415 13. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b382fc 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 16. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 20. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 21. asan_thread_start(void*) @ 0x000000000aa43059 22. ? @ 0x00007f35aab92ac3 23. ? @ 0x00007f35aac24850 2025.09.09 15:01:41.115325 [ 3604 ] {386e20b5-780d-4663-95d1-c031e0114621} executeQuery: Code: 36. DB::Exception: Codec DoubleDelta is only applicable for data types of size 1, 2, 4, 8 bytes. Given type Decimal(38, 10). (BAD_ARGUMENTS) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:33508) (comment: 01380_coded_delta_exception_code.sql) (in query: CREATE TABLE delta_codec_synthetic (`id` Decimal(38, 10) CODEC(DoubleDelta, ZSTD(22))) ENGINE = MergeTree ORDER BY tuple() SETTINGS index_granularity = 45552, min_bytes_for_wide_part = 1073741824, ratio_of_defaults_for_sparse_serialization = 0.09494186192750931, replace_long_file_name_to_hash = false, max_file_name_length = 37, min_bytes_for_full_part_storage = 470025013, compact_parts_max_bytes_to_buffer = 295120540, compact_parts_max_granules_to_buffer = 141, compact_parts_merge_max_bytes_to_prefetch_part = 31699090, merge_max_block_size = 18362, old_parts_lifetime = 19., prefer_fetch_merged_part_size_threshold = 10737418240, vertical_merge_algorithm_min_rows_to_activate = 632661, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 8477081882, index_granularity_bytes = 30147191, concurrent_part_removal_threshold = 100, allow_vertical_merges_from_compact_to_wide_parts = true, cache_populated_by_fetch = true, marks_compress_block_size = 63569, primary_key_compress_block_size = 29258), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000aad4b34 4. ./build_docker/./src/Compression/CompressionCodecDoubleDelta.cpp:456: 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*) @ 0x00000000277d763d 5. ./build_docker/./src/Compression/CompressionFactoryAdditions.cpp:135: void std::__function::__policy_invoker::__call_impl const&, std::shared_ptr const&, bool, bool, bool, bool) const::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x00000000291e960b 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000027a9e455 7. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:106: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x0000000027a9ea65 8. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:100: DB::CompressionCodecFactory::validateCodecAndGetPreprocessedAST(std::shared_ptr const&, std::shared_ptr const&, bool, bool, bool, bool) const @ 0x00000000291e6e9d 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:699: DB::InterpreterCreateQuery::getColumnsDescription(DB::ASTExpressionList const&, std::shared_ptr, DB::LoadingStrictnessLevel, bool) @ 0x000000002919a3c8 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&, DB::LoadingStrictnessLevel) const @ 0x000000002919cf0e 11. ./src/Parsers/ASTCreateQuery.h:175: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291aa55d 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000291c3415 13. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b382fc 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 16. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 20. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 21. asan_thread_start(void*) @ 0x000000000aa43059 22. ? @ 0x00007f35aab92ac3 23. ? @ 0x00007f35aac24850 2025.09.09 15:01:41.117800 [ 3604 ] {386e20b5-780d-4663-95d1-c031e0114621} TCPHandler: Code: 36. DB::Exception: Codec DoubleDelta is only applicable for data types of size 1, 2, 4, 8 bytes. Given type Decimal(38, 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000aad4b34 4. ./build_docker/./src/Compression/CompressionCodecDoubleDelta.cpp:456: 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*) @ 0x00000000277d763d 5. ./build_docker/./src/Compression/CompressionFactoryAdditions.cpp:135: void std::__function::__policy_invoker::__call_impl const&, std::shared_ptr const&, bool, bool, bool, bool) const::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x00000000291e960b 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000027a9e455 7. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:106: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x0000000027a9ea65 8. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:100: DB::CompressionCodecFactory::validateCodecAndGetPreprocessedAST(std::shared_ptr const&, std::shared_ptr const&, bool, bool, bool, bool) const @ 0x00000000291e6e9d 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:699: DB::InterpreterCreateQuery::getColumnsDescription(DB::ASTExpressionList const&, std::shared_ptr, DB::LoadingStrictnessLevel, bool) @ 0x000000002919a3c8 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&, DB::LoadingStrictnessLevel) const @ 0x000000002919cf0e 11. ./src/Parsers/ASTCreateQuery.h:175: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291aa55d 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000291c3415 13. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b382fc 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 16. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 20. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 21. asan_thread_start(void*) @ 0x000000000aa43059 22. ? @ 0x00007f35aab92ac3 23. ? @ 0x00007f35aac24850 2025.09.09 15:01:41.281093 [ 3604 ] {49b68a49-9a5a-45e3-910b-7222ce2dd879} executeQuery: Code: 36. DB::Exception: Codec Gorilla is only applicable for data types of size 1, 2, 4, 8 bytes. Given type Decimal(38, 10). (BAD_ARGUMENTS) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:33508) (comment: 01380_coded_delta_exception_code.sql) (in query: CREATE TABLE delta_codec_synthetic (`id` Decimal(38, 10) CODEC(Gorilla, ZSTD(22))) ENGINE = MergeTree ORDER BY tuple() SETTINGS index_granularity = 45552, min_bytes_for_wide_part = 1073741824, ratio_of_defaults_for_sparse_serialization = 0.09494186192750931, replace_long_file_name_to_hash = false, max_file_name_length = 37, min_bytes_for_full_part_storage = 470025013, compact_parts_max_bytes_to_buffer = 295120540, compact_parts_max_granules_to_buffer = 141, compact_parts_merge_max_bytes_to_prefetch_part = 31699090, merge_max_block_size = 18362, old_parts_lifetime = 19., prefer_fetch_merged_part_size_threshold = 10737418240, vertical_merge_algorithm_min_rows_to_activate = 632661, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 8477081882, index_granularity_bytes = 30147191, concurrent_part_removal_threshold = 100, allow_vertical_merges_from_compact_to_wide_parts = true, cache_populated_by_fetch = true, marks_compress_block_size = 63569, primary_key_compress_block_size = 29258), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000aad4b34 4. ./build_docker/./src/Compression/CompressionCodecGorilla.cpp:350: 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*) @ 0x00000000277dcf9d 5. ./build_docker/./src/Compression/CompressionFactoryAdditions.cpp:135: void std::__function::__policy_invoker::__call_impl const&, std::shared_ptr const&, bool, bool, bool, bool) const::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x00000000291e960b 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000027a9e455 7. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:106: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x0000000027a9ea65 8. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:100: DB::CompressionCodecFactory::validateCodecAndGetPreprocessedAST(std::shared_ptr const&, std::shared_ptr const&, bool, bool, bool, bool) const @ 0x00000000291e6e9d 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:699: DB::InterpreterCreateQuery::getColumnsDescription(DB::ASTExpressionList const&, std::shared_ptr, DB::LoadingStrictnessLevel, bool) @ 0x000000002919a3c8 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&, DB::LoadingStrictnessLevel) const @ 0x000000002919cf0e 11. ./src/Parsers/ASTCreateQuery.h:175: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291aa55d 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000291c3415 13. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b382fc 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 16. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 20. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 21. asan_thread_start(void*) @ 0x000000000aa43059 22. ? @ 0x00007f35aab92ac3 23. ? @ 0x00007f35aac24850 2025.09.09 15:01:41.283156 [ 3604 ] {49b68a49-9a5a-45e3-910b-7222ce2dd879} TCPHandler: Code: 36. DB::Exception: Codec Gorilla is only applicable for data types of size 1, 2, 4, 8 bytes. Given type Decimal(38, 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000aad4b34 4. ./build_docker/./src/Compression/CompressionCodecGorilla.cpp:350: 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*) @ 0x00000000277dcf9d 5. ./build_docker/./src/Compression/CompressionFactoryAdditions.cpp:135: void std::__function::__policy_invoker::__call_impl const&, std::shared_ptr const&, bool, bool, bool, bool) const::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x00000000291e960b 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000027a9e455 7. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:106: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x0000000027a9ea65 8. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:100: DB::CompressionCodecFactory::validateCodecAndGetPreprocessedAST(std::shared_ptr const&, std::shared_ptr const&, bool, bool, bool, bool) const @ 0x00000000291e6e9d 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:699: DB::InterpreterCreateQuery::getColumnsDescription(DB::ASTExpressionList const&, std::shared_ptr, DB::LoadingStrictnessLevel, bool) @ 0x000000002919a3c8 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&, DB::LoadingStrictnessLevel) const @ 0x000000002919cf0e 11. ./src/Parsers/ASTCreateQuery.h:175: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291aa55d 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000291c3415 13. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b382fc 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 16. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 20. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 21. asan_thread_start(void*) @ 0x000000000aa43059 22. ? @ 0x00007f35aab92ac3 23. ? @ 0x00007f35aac24850 2025.09.09 15:01:41.420592 [ 3604 ] {40e189a2-ea2d-4d37-8365-0492fe8771b2} executeQuery: Code: 433. DB::Exception: Argument value for DoubleDelta codec can be 1, 2, 4 or 8, given 3. (ILLEGAL_CODEC_PARAMETER) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:33508) (comment: 01380_coded_delta_exception_code.sql) (in query: CREATE TABLE delta_codec_synthetic (`id` UInt64 CODEC(DoubleDelta(3), ZSTD(22))) ENGINE = MergeTree ORDER BY tuple() SETTINGS index_granularity = 45552, min_bytes_for_wide_part = 1073741824, ratio_of_defaults_for_sparse_serialization = 0.09494186192750931, replace_long_file_name_to_hash = false, max_file_name_length = 37, min_bytes_for_full_part_storage = 470025013, compact_parts_max_bytes_to_buffer = 295120540, compact_parts_max_granules_to_buffer = 141, compact_parts_merge_max_bytes_to_prefetch_part = 31699090, merge_max_block_size = 18362, old_parts_lifetime = 19., prefer_fetch_merged_part_size_threshold = 10737418240, vertical_merge_algorithm_min_rows_to_activate = 632661, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 8477081882, index_granularity_bytes = 30147191, concurrent_part_removal_threshold = 100, allow_vertical_merges_from_compact_to_wide_parts = true, cache_populated_by_fetch = true, marks_compress_block_size = 63569, primary_key_compress_block_size = 29258), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, unsigned long&) @ 0x000000000c2c3e94 4. ./build_docker/./src/Compression/CompressionCodecDoubleDelta.cpp:573: 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*) @ 0x00000000277d75bd 5. ./build_docker/./src/Compression/CompressionFactoryAdditions.cpp:135: void std::__function::__policy_invoker::__call_impl const&, std::shared_ptr const&, bool, bool, bool, bool) const::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x00000000291e960b 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000027a9e455 7. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:106: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x0000000027a9ea65 8. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:100: DB::CompressionCodecFactory::validateCodecAndGetPreprocessedAST(std::shared_ptr const&, std::shared_ptr const&, bool, bool, bool, bool) const @ 0x00000000291e6e9d 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:699: DB::InterpreterCreateQuery::getColumnsDescription(DB::ASTExpressionList const&, std::shared_ptr, DB::LoadingStrictnessLevel, bool) @ 0x000000002919a3c8 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&, DB::LoadingStrictnessLevel) const @ 0x000000002919cf0e 11. ./src/Parsers/ASTCreateQuery.h:175: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291aa55d 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000291c3415 13. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b382fc 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 16. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 20. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 21. asan_thread_start(void*) @ 0x000000000aa43059 22. ? @ 0x00007f35aab92ac3 23. ? @ 0x00007f35aac24850 2025.09.09 15:01:41.422837 [ 3604 ] {40e189a2-ea2d-4d37-8365-0492fe8771b2} TCPHandler: Code: 433. DB::Exception: Argument value for DoubleDelta codec can be 1, 2, 4 or 8, given 3. (ILLEGAL_CODEC_PARAMETER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, unsigned long&) @ 0x000000000c2c3e94 4. ./build_docker/./src/Compression/CompressionCodecDoubleDelta.cpp:573: 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*) @ 0x00000000277d75bd 5. ./build_docker/./src/Compression/CompressionFactoryAdditions.cpp:135: void std::__function::__policy_invoker::__call_impl const&, std::shared_ptr const&, bool, bool, bool, bool) const::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x00000000291e960b 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000027a9e455 7. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:106: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x0000000027a9ea65 8. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:100: DB::CompressionCodecFactory::validateCodecAndGetPreprocessedAST(std::shared_ptr const&, std::shared_ptr const&, bool, bool, bool, bool) const @ 0x00000000291e6e9d 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:699: DB::InterpreterCreateQuery::getColumnsDescription(DB::ASTExpressionList const&, std::shared_ptr, DB::LoadingStrictnessLevel, bool) @ 0x000000002919a3c8 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&, DB::LoadingStrictnessLevel) const @ 0x000000002919cf0e 11. ./src/Parsers/ASTCreateQuery.h:175: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291aa55d 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000291c3415 13. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b382fc 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 16. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 20. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 21. asan_thread_start(void*) @ 0x000000000aa43059 22. ? @ 0x00007f35aab92ac3 23. ? @ 0x00007f35aac24850 2025.09.09 15:01:41.485960 [ 3604 ] {35632b7f-8152-458e-b977-b0cc61f71825} executeQuery: Code: 433. DB::Exception: Gorilla codec argument must be unsigned integer. (ILLEGAL_CODEC_PARAMETER) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:33508) (comment: 01380_coded_delta_exception_code.sql) (in query: CREATE TABLE delta_codec_synthetic (`id` UInt64 CODEC(Gorilla('hello, world'), ZSTD(22))) ENGINE = MergeTree ORDER BY tuple() SETTINGS index_granularity = 45552, min_bytes_for_wide_part = 1073741824, ratio_of_defaults_for_sparse_serialization = 0.09494186192750931, replace_long_file_name_to_hash = false, max_file_name_length = 37, min_bytes_for_full_part_storage = 470025013, compact_parts_max_bytes_to_buffer = 295120540, compact_parts_max_granules_to_buffer = 141, compact_parts_merge_max_bytes_to_prefetch_part = 31699090, merge_max_block_size = 18362, old_parts_lifetime = 19., prefer_fetch_merged_part_size_threshold = 10737418240, vertical_merge_algorithm_min_rows_to_activate = 632661, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 8477081882, index_granularity_bytes = 30147191, concurrent_part_removal_threshold = 100, allow_vertical_merges_from_compact_to_wide_parts = true, cache_populated_by_fetch = true, marks_compress_block_size = 63569, primary_key_compress_block_size = 29258), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aac868e 4. ./build_docker/./src/Compression/CompressionCodecGorilla.cpp:468: 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*) @ 0x00000000277dcc98 5. ./build_docker/./src/Compression/CompressionFactoryAdditions.cpp:135: void std::__function::__policy_invoker::__call_impl const&, std::shared_ptr const&, bool, bool, bool, bool) const::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x00000000291e960b 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000027a9e455 7. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:106: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x0000000027a9ea65 8. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:100: DB::CompressionCodecFactory::validateCodecAndGetPreprocessedAST(std::shared_ptr const&, std::shared_ptr const&, bool, bool, bool, bool) const @ 0x00000000291e6e9d 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:699: DB::InterpreterCreateQuery::getColumnsDescription(DB::ASTExpressionList const&, std::shared_ptr, DB::LoadingStrictnessLevel, bool) @ 0x000000002919a3c8 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&, DB::LoadingStrictnessLevel) const @ 0x000000002919cf0e 11. ./src/Parsers/ASTCreateQuery.h:175: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291aa55d 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000291c3415 13. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b382fc 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 16. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 20. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 21. asan_thread_start(void*) @ 0x000000000aa43059 22. ? @ 0x00007f35aab92ac3 23. ? @ 0x00007f35aac24850 2025.09.09 15:01:41.488422 [ 3604 ] {35632b7f-8152-458e-b977-b0cc61f71825} TCPHandler: Code: 433. DB::Exception: Gorilla codec argument must be unsigned integer. (ILLEGAL_CODEC_PARAMETER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aac868e 4. ./build_docker/./src/Compression/CompressionCodecGorilla.cpp:468: 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*) @ 0x00000000277dcc98 5. ./build_docker/./src/Compression/CompressionFactoryAdditions.cpp:135: void std::__function::__policy_invoker::__call_impl const&, std::shared_ptr const&, bool, bool, bool, bool) const::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x00000000291e960b 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000027a9e455 7. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:106: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x0000000027a9ea65 8. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:100: DB::CompressionCodecFactory::validateCodecAndGetPreprocessedAST(std::shared_ptr const&, std::shared_ptr const&, bool, bool, bool, bool) const @ 0x00000000291e6e9d 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:699: DB::InterpreterCreateQuery::getColumnsDescription(DB::ASTExpressionList const&, std::shared_ptr, DB::LoadingStrictnessLevel, bool) @ 0x000000002919a3c8 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&, DB::LoadingStrictnessLevel) const @ 0x000000002919cf0e 11. ./src/Parsers/ASTCreateQuery.h:175: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291aa55d 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000291c3415 13. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b382fc 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 16. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 20. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 21. asan_thread_start(void*) @ 0x000000000aa43059 22. ? @ 0x00007f35aab92ac3 23. ? @ 0x00007f35aac24850 2025.09.09 15:01:41.708394 [ 2902 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:01:41.751001 [ 2915 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:01:42.710513 [ 2958 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:01:42.753408 [ 2956 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:01:43.713907 [ 2981 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:01:43.758650 [ 2989 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:01:44.716352 [ 3004 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:01:44.760996 [ 3005 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:01:45.719105 [ 3029 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:01:45.763627 [ 3034 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:01:46.722025 [ 3054 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:01:46.768648 [ 3056 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:01:47.725112 [ 3072 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:01:47.772038 [ 3071 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:01:48.341321 [ 3604 ] {02901_parallel_replicas_rollup-test_15} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=773, jobs=736). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:33536) (comment: 02901_parallel_replicas_rollup.sh) (in query: SELECT 1 FROM nested GROUP BY 1 WITH ROLLUP ORDER BY max((SELECT 1 WHERE 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af872f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af7b2d1 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af7c3f3 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d36920d 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000002d369e5f 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processOrdinaryQuery() @ 0x000000002d18af7b 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d17644a 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 15. asan_thread_start(void*) @ 0x000000000aa43059 16. ? @ 0x00007f35aab92ac3 17. ? @ 0x00007f35aac24850 2025.09.09 15:01:48.360012 [ 3604 ] {02901_parallel_replicas_rollup-test_15} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=773, jobs=736). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af872f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af7b2d1 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af7c3f3 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d36920d 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000002d369e5f 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processOrdinaryQuery() @ 0x000000002d18af7b 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d17644a 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 15. asan_thread_start(void*) @ 0x000000000aa43059 16. ? @ 0x00007f35aab92ac3 17. ? @ 0x00007f35aac24850 2025.09.09 15:01:48.727530 [ 3097 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:01:48.774319 [ 3105 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:01:49.729938 [ 3120 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:01:49.776474 [ 3129 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:01:50.732432 [ 3157 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:01:50.810100 [ 3154 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:01:51.065876 [ 3612 ] {2e37042d-3992-4183-84d0-d440bd90ef74} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=0, jobs=0). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:50052) (comment: 02901_parallel_replicas_rollup.sh) (in query: SELECT initial_query_id, concat('Used parallel replicas: ', (countIf(initial_query_id != query_id) != 0)::bool::String) as used FROM system.query_log WHERE event_date >= yesterday() AND initial_query_id = '02901_parallel_replicas_rollup-test_15' GROUP BY initial_query_id ORDER BY min(event_time_microseconds) ASC 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af80b71 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af82f33 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002c64fc80 7. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1723: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr, unsigned long, std::shared_ptr, std::equal_to, std::allocator>>>, DB::MergeTreeData const&, std::vector> const&, std::shared_ptr, std::optional&, bool) @ 0x000000002de379fd 8. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1437: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000002de3554f 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:0: DB::ReadFromMergeTree::getAnalysisResult() const @ 0x000000002de41345 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:2022: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000002de4404c 11. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000002ddb933c 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000002ddff11e 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000002942117f 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x00000000294209e7 15. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b382fc 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 18. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 22. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:01:51.071144 [ 3612 ] {2e37042d-3992-4183-84d0-d440bd90ef74} 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af80b71 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af82f33 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002c64fc80 7. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1723: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr, unsigned long, std::shared_ptr, std::equal_to, std::allocator>>>, DB::MergeTreeData const&, std::vector> const&, std::shared_ptr, std::optional&, bool) @ 0x000000002de379fd 8. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1437: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000002de3554f 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:0: DB::ReadFromMergeTree::getAnalysisResult() const @ 0x000000002de41345 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:2022: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000002de4404c 11. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000002ddb933c 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000002ddff11e 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000002942117f 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x00000000294209e7 15. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b382fc 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 18. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 22. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:01:51.734626 [ 3181 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:01:51.813329 [ 3178 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:01:52.736654 [ 3195 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:01:52.815538 [ 3190 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:01:53.738869 [ 3220 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:01:53.820424 [ 3215 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:01:54.741854 [ 3234 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:01:54.823519 [ 3241 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:01:55.744383 [ 2736 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:01:55.825845 [ 2751 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:01:56.746449 [ 2778 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:01:56.827896 [ 2779 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:01:57.748523 [ 2812 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:01:57.860333 [ 2801 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:01:58.751143 [ 2823 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:01:58.862708 [ 2825 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:01:59.753545 [ 2835 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:01:59.864927 [ 2848 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:02:00.757249 [ 2866 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:02:00.868116 [ 2877 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:02:01.760148 [ 2889 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:02:01.870480 [ 2899 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:02:02.762322 [ 2915 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:02:02.872981 [ 2926 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:02:03.764552 [ 2951 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:02:03.882158 [ 2949 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:02:04.767393 [ 2989 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:02:04.884501 [ 2998 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:02:05.774258 [ 3021 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:02:05.886740 [ 3015 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:02:06.685728 [ 3604 ] {3d5b65b5-748f-4cf5-891f-0218872a6d29} executeQuery: Code: 48. DB::Exception: Truncate is not supported by storage FuzzJSON. (NOT_IMPLEMENTED) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:55160) (comment: 02919_storage_fuzzjson.sql) (in query: DROP TABLE IF EXISTS 02919_test_table_noarg;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::IStorage::truncate(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, DB::TableExclusiveLockHolder&) @ 0x00000000260e9270 4. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:279: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x00000000291f066f 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x00000000291ed665 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x00000000291ebd68 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x00000000291eb7ed 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b382fc 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 11. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 15. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 16. asan_thread_start(void*) @ 0x000000000aa43059 17. ? @ 0x00007f35aab92ac3 18. ? @ 0x00007f35aac24850 2025.09.09 15:02:06.687733 [ 3604 ] {3d5b65b5-748f-4cf5-891f-0218872a6d29} TCPHandler: Code: 48. DB::Exception: Truncate is not supported by storage FuzzJSON. (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::IStorage::truncate(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, DB::TableExclusiveLockHolder&) @ 0x00000000260e9270 4. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:279: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x00000000291f066f 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x00000000291ed665 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x00000000291ebd68 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x00000000291eb7ed 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b382fc 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 11. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 15. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 16. asan_thread_start(void*) @ 0x000000000aa43059 17. ? @ 0x00007f35aab92ac3 18. ? @ 0x00007f35aac24850 2025.09.09 15:02:06.776592 [ 3031 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:02:06.888914 [ 3041 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:02:07.779315 [ 3050 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:02:07.894631 [ 3060 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:02:07.975868 [ 3612 ] {7d19285e-3c20-4414-9962-9528dbeffe4d} executeQuery: Code: 42. DB::Exception: Incorrect number of arguments for aggregate function with ArgMin suffix. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:55174) (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000aad4b34 4. ./build_docker/./src/AggregateFunctions/Combinators/AggregateFunctionCombinatorsArgMinArgMax.cpp:194: DB::(anonymous namespace)::CombinatorArgMinArgMax::transformArguments(std::vector, std::allocator>> const&) const @ 0x0000000025de79a9 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 @ 0x00000000265b465c 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 @ 0x00000000265b1c12 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002839a287 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000028367bce 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028366290 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283b62c9 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002835ae03 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000028359104 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000028357f0d 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002921bdcc 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&) @ 0x000000002941f313 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&) @ 0x0000000029419aef 17. ./contrib/llvm-project/libcxx/include/vector:432: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000029421f5d 18. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000029344c1b 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*) @ 0x0000000029b3703b 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 21. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 22. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 26. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 27. asan_thread_start(void*) @ 0x000000000aa43059 28. ? @ 0x00007f35aab92ac3 29. ? @ 0x00007f35aac24850 2025.09.09 15:02:07.985998 [ 3612 ] {7d19285e-3c20-4414-9962-9528dbeffe4d} 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000aad4b34 4. ./build_docker/./src/AggregateFunctions/Combinators/AggregateFunctionCombinatorsArgMinArgMax.cpp:194: DB::(anonymous namespace)::CombinatorArgMinArgMax::transformArguments(std::vector, std::allocator>> const&) const @ 0x0000000025de79a9 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 @ 0x00000000265b465c 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 @ 0x00000000265b1c12 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002839a287 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000028367bce 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028366290 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283b62c9 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002835ae03 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000028359104 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000028357f0d 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002921bdcc 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&) @ 0x000000002941f313 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&) @ 0x0000000029419aef 17. ./contrib/llvm-project/libcxx/include/vector:432: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000029421f5d 18. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000029344c1b 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*) @ 0x0000000029b3703b 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 21. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 22. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 26. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 27. asan_thread_start(void*) @ 0x000000000aa43059 28. ? @ 0x00007f35aab92ac3 29. ? @ 0x00007f35aac24850 2025.09.09 15:02:08.151777 [ 3612 ] {8f4e7c6b-b11f-45b2-9533-991db18c3b1b} executeQuery: Code: 42. DB::Exception: Aggregate function sum requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:55174) (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 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*) @ 0x000000002456e2bc 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000265b499e 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 @ 0x00000000265b1c12 7. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:0: DB::AggregateFunctionFactory::getImpl(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&, bool) const @ 0x00000000265b46da 8. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:124: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x00000000265b1c12 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002839a287 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000028367bce 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028366290 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283b62c9 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002835ae03 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000028359104 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000028357f0d 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002921bdcc 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&) @ 0x000000002941f313 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&) @ 0x0000000029419aef 19. ./contrib/llvm-project/libcxx/include/vector:432: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000029421f5d 20. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000029344c1b 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*) @ 0x0000000029b3703b 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 23. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 24. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 29. asan_thread_start(void*) @ 0x000000000aa43059 30. ? @ 0x00007f35aab92ac3 31. ? @ 0x00007f35aac24850 2025.09.09 15:02:08.157331 [ 3612 ] {8f4e7c6b-b11f-45b2-9533-991db18c3b1b} 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 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*) @ 0x000000002456e2bc 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000265b499e 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 @ 0x00000000265b1c12 7. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:0: DB::AggregateFunctionFactory::getImpl(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&, bool) const @ 0x00000000265b46da 8. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:124: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x00000000265b1c12 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002839a287 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000028367bce 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028366290 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283b62c9 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002835ae03 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000028359104 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000028357f0d 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002921bdcc 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&) @ 0x000000002941f313 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&) @ 0x0000000029419aef 19. ./contrib/llvm-project/libcxx/include/vector:432: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000029421f5d 20. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000029344c1b 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*) @ 0x0000000029b3703b 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 23. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 24. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 29. asan_thread_start(void*) @ 0x000000000aa43059 30. ? @ 0x00007f35aab92ac3 31. ? @ 0x00007f35aac24850 2025.09.09 15:02:08.331353 [ 3612 ] {c99b74a9-b635-4f6c-87f0-1a2d8f9301dc} 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.10505.altinitytest (altinity build)) (from [::1]:55174) (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa91e9a 4. ./build_docker/./src/AggregateFunctions/Combinators/AggregateFunctionCombinatorsArgMinArgMax.cpp:61: DB::(anonymous namespace)::CombinatorArgMinArgMax::transformAggregateFunction(std::shared_ptr const&, DB::AggregateFunctionProperties const&, std::vector, std::allocator>> const&, DB::Array const&) const @ 0x0000000025de867d 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 @ 0x00000000265b4737 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 @ 0x00000000265b1c12 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002839a287 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000028367bce 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028366290 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283b62c9 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002835ae03 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000028359104 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000028357f0d 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002921bdcc 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&) @ 0x000000002941f313 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&) @ 0x0000000029419aef 17. ./contrib/llvm-project/libcxx/include/vector:432: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000029421f5d 18. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000029344c1b 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*) @ 0x0000000029b3703b 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 21. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 22. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 26. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 27. asan_thread_start(void*) @ 0x000000000aa43059 28. ? @ 0x00007f35aab92ac3 29. ? @ 0x00007f35aac24850 2025.09.09 15:02:08.335007 [ 3612 ] {c99b74a9-b635-4f6c-87f0-1a2d8f9301dc} 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa91e9a 4. ./build_docker/./src/AggregateFunctions/Combinators/AggregateFunctionCombinatorsArgMinArgMax.cpp:61: DB::(anonymous namespace)::CombinatorArgMinArgMax::transformAggregateFunction(std::shared_ptr const&, DB::AggregateFunctionProperties const&, std::vector, std::allocator>> const&, DB::Array const&) const @ 0x0000000025de867d 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 @ 0x00000000265b4737 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 @ 0x00000000265b1c12 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002839a287 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000028367bce 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028366290 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283b62c9 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002835ae03 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000028359104 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000028357f0d 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002921bdcc 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&) @ 0x000000002941f313 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&) @ 0x0000000029419aef 17. ./contrib/llvm-project/libcxx/include/vector:432: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000029421f5d 18. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000029344c1b 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*) @ 0x0000000029b3703b 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 21. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 22. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 26. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 27. asan_thread_start(void*) @ 0x000000000aa43059 28. ? @ 0x00007f35aab92ac3 29. ? @ 0x00007f35aac24850 2025.09.09 15:02:08.432115 [ 3612 ] {c531b094-5312-4e54-8d0c-7313cb25cf9f} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=1, jobs=1). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:55174) (comment: 02885_arg_min_max_combinator.sql) (in query: -- ASAN (data leak) SELECT sumArgMax(number, tuple(number, repeat('a', (10 * (number % 100))::Int32))) FROM numbers(1000);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af80b71 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80746 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d34b5ca 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000002d3486e4 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000002d34827b 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002d36bcf7 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 12. asan_thread_start(void*) @ 0x000000000aa43059 13. ? @ 0x00007f35aab92ac3 14. ? @ 0x00007f35aac24850 2025.09.09 15:02:08.434388 [ 3612 ] {c531b094-5312-4e54-8d0c-7313cb25cf9f} 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af80b71 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80746 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d34b5ca 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000002d3486e4 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000002d34827b 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002d36bcf7 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 12. asan_thread_start(void*) @ 0x000000000aa43059 13. ? @ 0x00007f35aab92ac3 14. ? @ 0x00007f35aac24850 2025.09.09 15:02:08.781718 [ 3076 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:02:08.897531 [ 3089 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:02:09.784009 [ 3092 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:02:09.899203 [ 3111 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:02:10.786540 [ 3134 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:02:10.901623 [ 3138 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:02:11.724511 [ 3337 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {ccc63915-230c-46e1-a015-6f55b3fb64ee::202509_1_116_23}: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=13, jobs=2). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af80b71 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80746 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002c765aab 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:1197: ? @ 0x000000002c7602b8 8. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x000000002c75fc2b 9. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:0: DB::MergeTreeReaderCompact::MergeTreeReaderCompact(std::shared_ptr, DB::NamesAndTypesList, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*, DB::MarkCache*, DB::MarkRanges, DB::MergeTreeReaderSettings, std::map, std::allocator>>, std::function const&, int) @ 0x000000002c7aee03 10. ./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.h:16: DB::MergeTreeReaderCompactSingleBuffer::MergeTreeReaderCompactSingleBuffer&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int&&) @ 0x000000002c5d6d21 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::MergeTreeDataPartCompact::getReader(DB::NamesAndTypesList const&, std::shared_ptr const&, DB::MarkRanges const&, std::unordered_map, std::equal_to, std::allocator>> const&, DB::UncompressedCache*, DB::MarkCache*, std::shared_ptr const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) const @ 0x000000002c5d1037 12. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:169: DB::MergeTreeSequentialSource::MergeTreeSequentialSource(DB::MergeTreeSequentialSourceType, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::vector>, std::optional, bool, bool, bool) @ 0x000000002c80c330 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:35: DB::MergeTreeSequentialSource* std::construct_at[abi:v15007] const&, std::shared_ptr&, std::shared_ptr&, std::vector>&, std::optional, bool, bool&, bool&, DB::MergeTreeSequentialSource*>(DB::MergeTreeSequentialSource*, DB::MergeTreeSequentialSourceType&, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr&, std::shared_ptr&, std::vector>&, std::optional&&, bool&&, bool&, bool&) @ 0x000000002c81320f 14. ./contrib/llvm-project/libcxx/include/__memory/allocator_traits.h:298: DB::createMergeTreeSequentialSource(DB::MergeTreeSequentialSourceType, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::vector>, std::optional, std::shared_ptr>, bool, bool, bool) @ 0x000000002c810812 15. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1136: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::createMergedStream() @ 0x000000002c3dd079 16. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() @ 0x000000002c3d6516 17. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:534: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x000000002c3e2799 18. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::execute() @ 0x000000002c3ef3fe 19. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:0: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000002cc2f4c0 20. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000002c427f28 21. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000002c429675 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7eaf0 23. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001af8a79f 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 26. asan_thread_start(void*) @ 0x000000000aa43059 27. ? @ 0x00007f35aab92ac3 28. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:02:11.788854 [ 3177 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:02:11.903757 [ 3185 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:02:12.791373 [ 3214 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:02:12.907059 [ 3229 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:02:13.799991 [ 2747 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:02:13.909444 [ 2754 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:02:14.803538 [ 2772 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:02:14.911681 [ 2739 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:02:15.806290 [ 2790 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:02:15.914653 [ 2794 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:02:16.808526 [ 2798 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:02:16.917086 [ 2811 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:02:17.811468 [ 2815 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:02:17.932924 [ 2841 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:02:18.816297 [ 2854 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:02:18.935763 [ 2859 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:02:19.819457 [ 2884 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:02:19.943050 [ 2882 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:02:20.823072 [ 2918 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:02:20.945487 [ 2916 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:02:21.827050 [ 2942 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:02:21.948022 [ 2955 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:02:22.829807 [ 2988 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:02:22.950300 [ 2986 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:02:23.093810 [ 3612 ] {a53cde30-c604-4864-9664-cd09698bb6e7} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=773, jobs=735). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:49906) (comment: 00829_bitmap_function.sql) (in query: SELECT groupBitmapOr(z) FROM bitmap_column_expr_test2 WHERE like(tag_id, 'tag%');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af872f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af7b2d1 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af7c3f3 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d36920d 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000002d369e5f 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processOrdinaryQuery() @ 0x000000002d18af7b 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d17644a 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 15. asan_thread_start(void*) @ 0x000000000aa43059 16. ? @ 0x00007f35aab92ac3 17. ? @ 0x00007f35aac24850 2025.09.09 15:02:23.106806 [ 3612 ] {a53cde30-c604-4864-9664-cd09698bb6e7} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=773, 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af872f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af7b2d1 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af7c3f3 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d36920d 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000002d369e5f 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processOrdinaryQuery() @ 0x000000002d18af7b 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d17644a 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 15. asan_thread_start(void*) @ 0x000000000aa43059 16. ? @ 0x00007f35aab92ac3 17. ? @ 0x00007f35aac24850 2025.09.09 15:02:23.835126 [ 3008 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:02:23.952840 [ 3011 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:02:24.837638 [ 3019 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:02:24.955559 [ 3032 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:02:25.839905 [ 3056 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:02:25.958149 [ 3053 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:02:26.842523 [ 3070 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:02:26.961513 [ 3085 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:02:27.282641 [ 13328 ] {} DynamicQueryHandler: Code: 452. DB::Exception: Setting max_execution_time shouldn't be greater than 60. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x0000000026f841fa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:368: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f81de0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/find_if.h:25: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f808a4 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000002d065739 10. ./build_docker/./src/Server/HTTPHandler.cpp:705: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000002d06d139 11. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000002d1cc337 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 15. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 16. asan_thread_start(void*) @ 0x000000000aa43059 17. ? @ 0x00007f35aab92ac3 18. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:02:27.845657 [ 3099 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:02:27.965119 [ 3104 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:02:28.848769 [ 3130 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:02:28.968456 [ 3135 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:02:29.855344 [ 3148 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:02:29.971047 [ 3160 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:02:30.858373 [ 3181 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:02:30.974343 [ 3176 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:02:31.861527 [ 3196 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:02:31.977138 [ 3199 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:02:32.865557 [ 3217 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:02:32.984954 [ 3233 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:02:33.896300 [ 3241 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:02:33.987911 [ 2732 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:02:34.899770 [ 2765 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:02:34.991259 [ 2735 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:02:35.714222 [ 13328 ] {} DynamicQueryHandler: Code: 452. DB::Exception: Setting max_execution_time shouldn't be greater than 60. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x0000000026f841fa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:368: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f81de0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/find_if.h:25: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f808a4 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000002d065739 10. ./build_docker/./src/Server/HTTPHandler.cpp:705: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000002d06d139 11. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000002d1cc337 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 15. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 16. asan_thread_start(void*) @ 0x000000000aa43059 17. ? @ 0x00007f35aab92ac3 18. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:02:35.908060 [ 2769 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:02:35.994668 [ 2774 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:02:36.910482 [ 2796 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:02:36.997106 [ 2798 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:02:37.912788 [ 2826 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:02:37.999366 [ 2832 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:02:38.915702 [ 2848 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:02:39.005140 [ 2845 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:02:39.446521 [ 3604 ] {d0f5aec6-2e53-4701-89d9-193aa7dfabd8} executeQuery: Code: 36. DB::Exception: Cannot drop or clear columns 'nes.b, nes.a', because all columns in part 'all_1_1_0' will be removed from disk. Empty parts are not allowed. (BAD_ARGUMENTS) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:53578) (comment: 02500_prevent_drop_nested_if_empty_part.sql) (in query: ALTER TABLE 02500_nested DROP COLUMN nes;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&, String&&, String const&) @ 0x000000002c5571e0 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:3623: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x000000002c496b2f 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000029174532 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x0000000029170711 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b382fc 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 15. asan_thread_start(void*) @ 0x000000000aa43059 16. ? @ 0x00007f35aab92ac3 17. ? @ 0x00007f35aac24850 2025.09.09 15:02:39.449483 [ 3604 ] {d0f5aec6-2e53-4701-89d9-193aa7dfabd8} TCPHandler: Code: 36. DB::Exception: Cannot drop or clear columns 'nes.b, nes.a', because all columns in part 'all_1_1_0' 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&, String&&, String const&) @ 0x000000002c5571e0 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:3623: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x000000002c496b2f 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000029174532 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x0000000029170711 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b382fc 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 15. asan_thread_start(void*) @ 0x000000000aa43059 16. ? @ 0x00007f35aab92ac3 17. ? @ 0x00007f35aac24850 2025.09.09 15:02:39.918404 [ 2865 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:02:40.009125 [ 2866 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:02:40.035984 [ 3604 ] {286140f5-5335-464d-b9d0-8b694ef7019e} executeQuery: Code: 57. DB::Exception: Table test_3.`02500_nested` already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:53578) (comment: 02500_prevent_drop_nested_if_empty_part.sql) (in query: CREATE TABLE `02500_nested` (`nes` Nested(a Int32, b Int32)) ENGINE = MergeTree ORDER BY tuple() SETTINGS index_granularity = 38357, min_bytes_for_wide_part = 1073741824, ratio_of_defaults_for_sparse_serialization = 0.5781164765357971, replace_long_file_name_to_hash = false, max_file_name_length = 128, min_bytes_for_full_part_storage = 536870912, compact_parts_max_bytes_to_buffer = 38457959, compact_parts_max_granules_to_buffer = 90, compact_parts_merge_max_bytes_to_prefetch_part = 8813889, merge_max_block_size = 322, old_parts_lifetime = 10., prefer_fetch_merged_part_size_threshold = 1539016244, vertical_merge_algorithm_min_rows_to_activate = 1, vertical_merge_algorithm_min_columns_to_activate = 100, min_merge_bytes_to_use_direct_io = 1, index_granularity_bytes = 25259973, concurrent_part_removal_threshold = 0, allow_vertical_merges_from_compact_to_wide_parts = false, cache_populated_by_fetch = true, marks_compress_block_size = 61857, primary_key_compress_block_size = 82287), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa91e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1558: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291bc5ff 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291ac835 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000291c3415 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b382fc 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 15. asan_thread_start(void*) @ 0x000000000aa43059 16. ? @ 0x00007f35aab92ac3 17. ? @ 0x00007f35aac24850 2025.09.09 15:02:40.038203 [ 3604 ] {286140f5-5335-464d-b9d0-8b694ef7019e} TCPHandler: Code: 57. DB::Exception: Table test_3.`02500_nested` already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa91e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1558: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291bc5ff 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291ac835 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000291c3415 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b382fc 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 15. asan_thread_start(void*) @ 0x000000000aa43059 16. ? @ 0x00007f35aab92ac3 17. ? @ 0x00007f35aac24850 2025.09.09 15:02:40.920982 [ 2884 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:02:41.012200 [ 2878 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:02:41.924533 [ 2910 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:02:42.014574 [ 2904 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:02:42.926778 [ 2944 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:02:43.016646 [ 2950 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:02:43.929793 [ 2969 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:02:44.019539 [ 2976 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:02:44.931978 [ 2993 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:02:45.021748 [ 3002 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:02:45.665901 [ 3604 ] {502a3e0e-b6bb-4ef5-9a50-6ae1fb12b9de} 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.10505.altinitytest (altinity build)) (from [::1]:53610) (comment: 03097_query_log_join_processes.sql) (in query: SELECT count(1) as num, hostName() as hostName FROM system.query_log as a INNER JOIN system.processes as b on a.query_id = b.query_id and type = 'QueryStart' and dateDiff('second', event_time, now()) > 5 and current_database = currentDatabase() FORMAT Null;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aac868e 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&) @ 0x00000000294a6d9f 5. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1490: DB::(anonymous namespace)::buildQueryPlanForJoinNode(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000002947642f 6. ./build_docker/./src/Planner/PlannerJoinTree.cpp:0: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000002945f174 7. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x000000002942c986 8. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x00000000294261fb 9. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000029421552 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1182: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3737e 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 13. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 18. asan_thread_start(void*) @ 0x000000000aa43059 19. ? @ 0x00007f35aab92ac3 20. ? @ 0x00007f35aac24850 2025.09.09 15:02:45.684354 [ 3604 ] {502a3e0e-b6bb-4ef5-9a50-6ae1fb12b9de} 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aac868e 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&) @ 0x00000000294a6d9f 5. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1490: DB::(anonymous namespace)::buildQueryPlanForJoinNode(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000002947642f 6. ./build_docker/./src/Planner/PlannerJoinTree.cpp:0: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000002945f174 7. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x000000002942c986 8. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x00000000294261fb 9. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000029421552 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1182: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3737e 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 13. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 18. asan_thread_start(void*) @ 0x000000000aa43059 19. ? @ 0x00007f35aab92ac3 20. ? @ 0x00007f35aac24850 2025.09.09 15:02:45.934724 [ 3019 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:02:46.023858 [ 3032 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:02:46.937518 [ 3052 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:02:47.026027 [ 3055 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:02:47.939572 [ 3079 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:02:48.028564 [ 3086 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:02:48.726560 [ 4023 ] {79805dcf-b00e-45f2-8bfb-b9d4f3c42a29} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=773, jobs=735). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:53620) (comment: 01271_optimize_arithmetic_operations_in_aggr_func_long.sql) (in query: EXPLAIN SYNTAX SELECT max(n*n * 2), max(2 * n*n), max(n*n / 2), max(1 / n*n) FROM (SELECT number n FROM numbers(10));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af872f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af7b2d1 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af7c3f3 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d36920d 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000002d369e5f 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processOrdinaryQuery() @ 0x000000002d18af7b 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d17644a 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 15. asan_thread_start(void*) @ 0x000000000aa43059 16. ? @ 0x00007f35aab92ac3 17. ? @ 0x00007f35aac24850 2025.09.09 15:02:48.729869 [ 4023 ] {79805dcf-b00e-45f2-8bfb-b9d4f3c42a29} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=773, 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af872f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af7b2d1 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af7c3f3 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d36920d 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000002d369e5f 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processOrdinaryQuery() @ 0x000000002d18af7b 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d17644a 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 15. asan_thread_start(void*) @ 0x000000000aa43059 16. ? @ 0x00007f35aab92ac3 17. ? @ 0x00007f35aac24850 2025.09.09 15:02:48.942266 [ 3108 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:02:49.031986 [ 3111 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:02:49.944865 [ 3126 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:02:50.035063 [ 3130 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:02:50.039051 [ 3604 ] {da906711-8830-442a-b77e-8477ed42c275} executeQuery: Code: 117. DB::Exception: Line cannot be computed between start H3 index 72057594037927935 and end H3 index 72057594037927935: In scope SELECT h3Line(72057594037927935, 72057594037927935). (INCORRECT_DATA) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:53634) (comment: 02293_h3_line.sql) (in query: SELECT h3Line(0xffffffffffffff, 0xffffffffffffff);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long const&, unsigned long const&) @ 0x000000000f223b7a 4. DB::(anonymous namespace)::FunctionH3Line::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000011a94bab 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aa8c635 6. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aac91d5 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000cccccfb 8. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000cccc1ab 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccccc2a 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccce65c 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd2030 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002839a3af 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000028367bce 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028366290 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283b62c9 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002835ae03 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000028359104 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000028357f0d 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002921bdcc 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&) @ 0x000000002941f313 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&) @ 0x0000000029419aef 22. ./contrib/llvm-project/libcxx/include/vector:432: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000029421f5d 23. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000029344c1b 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*) @ 0x0000000029b3703b 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 27. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 31. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 2025.09.09 15:02:50.044150 [ 3604 ] {da906711-8830-442a-b77e-8477ed42c275} TCPHandler: Code: 117. DB::Exception: Line cannot be computed between start H3 index 72057594037927935 and end H3 index 72057594037927935: In scope SELECT h3Line(72057594037927935, 72057594037927935). (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long const&, unsigned long const&) @ 0x000000000f223b7a 4. DB::(anonymous namespace)::FunctionH3Line::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000011a94bab 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aa8c635 6. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aac91d5 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000cccccfb 8. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000cccc1ab 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccccc2a 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccce65c 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd2030 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002839a3af 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000028367bce 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028366290 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283b62c9 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002835ae03 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000028359104 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000028357f0d 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002921bdcc 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&) @ 0x000000002941f313 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&) @ 0x0000000029419aef 22. ./contrib/llvm-project/libcxx/include/vector:432: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000029421f5d 23. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000029344c1b 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*) @ 0x0000000029b3703b 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 27. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 31. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 2025.09.09 15:02:51.037147 [ 3153 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:02:51.038369 [ 3147 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:02:51.081776 [ 3604 ] {67b02621-91ab-4534-b03f-f734f0188ae5} executeQuery: Code: 57. DB::Exception: Table test_15.tab already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:48954) (comment: 02903_bug_43644.sql) (in query: CREATE TABLE tab (`machine_id` UInt64, `name` String, `timestamp` DateTime) ENGINE = MergeTree PARTITION BY toYYYYMM(timestamp) ORDER BY machine_id SETTINGS index_granularity = 39104, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 0., replace_long_file_name_to_hash = false, max_file_name_length = 0, min_bytes_for_full_part_storage = 187254616, compact_parts_max_bytes_to_buffer = 164466230, compact_parts_max_granules_to_buffer = 256, compact_parts_merge_max_bytes_to_prefetch_part = 31144472, merge_max_block_size = 14862, old_parts_lifetime = 46., 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 = 8963786419, index_granularity_bytes = 21658994, concurrent_part_removal_threshold = 0, allow_vertical_merges_from_compact_to_wide_parts = false, cache_populated_by_fetch = true, marks_compress_block_size = 57558, primary_key_compress_block_size = 45778), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa91e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1558: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291bc5ff 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291ac835 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000291c3415 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b382fc 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 15. asan_thread_start(void*) @ 0x000000000aa43059 16. ? @ 0x00007f35aab92ac3 17. ? @ 0x00007f35aac24850 2025.09.09 15:02:51.103523 [ 3604 ] {67b02621-91ab-4534-b03f-f734f0188ae5} TCPHandler: Code: 57. DB::Exception: Table test_15.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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa91e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1558: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291bc5ff 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291ac835 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000291c3415 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b382fc 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 15. asan_thread_start(void*) @ 0x000000000aa43059 16. ? @ 0x00007f35aab92ac3 17. ? @ 0x00007f35aac24850 2025.09.09 15:02:52.040349 [ 3164 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:02:52.041561 [ 3178 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:02:53.042675 [ 3205 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:02:53.045838 [ 3208 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:02:54.044825 [ 3225 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:02:54.047906 [ 3218 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:02:55.055189 [ 2745 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:02:55.055292 [ 2733 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:02:56.008121 [ 2740 ] {} 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af819ed 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80746 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000263a174e 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000286c6b9c 8. ./contrib/llvm-project/libcxx/include/vector:590: DB::DatabaseCatalog::dropTableDataTask() @ 0x00000000286c7466 9. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 11. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 14. asan_thread_start(void*) @ 0x000000000aa43059 15. ? @ 0x00007f35aab92ac3 16. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:02:56.057179 [ 2764 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:02:56.057467 [ 2735 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:02:56.442290 [ 4023 ] {a0f045a3-8240-4dbf-b956-055e0ced9516} executeQuery: Code: 107. DB::Exception: File /var/lib/clickhouse/user_files/data.jsonl doesn't exist. (FILE_DOESNT_EXIST) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:49074) (comment: 02222_create_table_without_columns_metadata.sh) (in query: select * from test), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 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) @ 0x000000002b79db62 5. ./build_docker/./src/Planner/PlannerJoinTree.cpp:880: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x0000000029469c4b 6. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1795: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000002945d99d 7. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x000000002942c986 8. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x00000000294261fb 9. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000029421552 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1182: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3737e 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 13. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 18. asan_thread_start(void*) @ 0x000000000aa43059 19. ? @ 0x00007f35aab92ac3 20. ? @ 0x00007f35aac24850 2025.09.09 15:02:56.457643 [ 4023 ] {a0f045a3-8240-4dbf-b956-055e0ced9516} TCPHandler: Code: 107. DB::Exception: File /var/lib/clickhouse/user_files/data.jsonl 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 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) @ 0x000000002b79db62 5. ./build_docker/./src/Planner/PlannerJoinTree.cpp:880: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x0000000029469c4b 6. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1795: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000002945d99d 7. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x000000002942c986 8. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x00000000294261fb 9. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000029421552 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1182: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3737e 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 13. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 18. asan_thread_start(void*) @ 0x000000000aa43059 19. ? @ 0x00007f35aab92ac3 20. ? @ 0x00007f35aac24850 2025.09.09 15:02:57.059668 [ 2775 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:02:57.060726 [ 2777 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:02:57.935464 [ 3612 ] {23d7cd33-83ca-431e-bb4e-21e4291aefde} executeQuery: Code: 57. DB::Exception: Table test_3.test already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:49098) (comment: 02222_create_table_without_columns_metadata.sh) (in query: create table test (x 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa91e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1558: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291bc5ff 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291ac835 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000291c3415 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b382fc 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 15. asan_thread_start(void*) @ 0x000000000aa43059 16. ? @ 0x00007f35aab92ac3 17. ? @ 0x00007f35aac24850 2025.09.09 15:02:57.946424 [ 3612 ] {23d7cd33-83ca-431e-bb4e-21e4291aefde} TCPHandler: Code: 57. DB::Exception: Table test_3.test already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa91e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1558: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291bc5ff 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291ac835 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000291c3415 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b382fc 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 15. asan_thread_start(void*) @ 0x000000000aa43059 16. ? @ 0x00007f35aab92ac3 17. ? @ 0x00007f35aac24850 2025.09.09 15:02:58.064060 [ 2786 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:02:58.110337 [ 2806 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:02:59.066108 [ 2810 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:02:59.107476 [ 4023 ] {4cf94f95-2418-447d-b6d0-9a0729ccd4d0} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=773, jobs=735). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:49084) (comment: 00222_sequence_aggregate_function_family.sql) (in query: select 1 = sequenceMatch('(?1)(?1)(?1)(?1)')(time, data = 0, data = 1, data = 2, data = 3) from sequence_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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af872f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af7b2d1 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af7c3f3 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d36920d 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000002d369e5f 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processOrdinaryQuery() @ 0x000000002d18af7b 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d17644a 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 15. asan_thread_start(void*) @ 0x000000000aa43059 16. ? @ 0x00007f35aab92ac3 17. ? @ 0x00007f35aac24850 2025.09.09 15:02:59.110107 [ 4023 ] {4cf94f95-2418-447d-b6d0-9a0729ccd4d0} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=773, 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af872f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af7b2d1 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af7c3f3 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d36920d 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000002d369e5f 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processOrdinaryQuery() @ 0x000000002d18af7b 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d17644a 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 15. asan_thread_start(void*) @ 0x000000000aa43059 16. ? @ 0x00007f35aab92ac3 17. ? @ 0x00007f35aac24850 2025.09.09 15:02:59.112951 [ 2804 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:03:00.068765 [ 2834 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:03:00.139120 [ 2837 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:03:00.492135 [ 3612 ] {bbf34cb4-5278-4c2c-b531-3cd8a1c05871} executeQuery: Code: 57. DB::Exception: Table test_15.t2 already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:47714) (comment: 02968_full_sorting_join_fuzz.sql) (in query: CREATE TABLE t2 (`key` UInt32, `s` String) ENGINE = MergeTree ORDER BY key SETTINGS index_granularity = 59791, min_bytes_for_wide_part = 775729771, ratio_of_defaults_for_sparse_serialization = 0., replace_long_file_name_to_hash = false, max_file_name_length = 0, min_bytes_for_full_part_storage = 344044922, compact_parts_max_bytes_to_buffer = 303713367, compact_parts_max_granules_to_buffer = 1, compact_parts_merge_max_bytes_to_prefetch_part = 17100726, merge_max_block_size = 16024, old_parts_lifetime = 480., prefer_fetch_merged_part_size_threshold = 10737418240, vertical_merge_algorithm_min_rows_to_activate = 1, vertical_merge_algorithm_min_columns_to_activate = 100, min_merge_bytes_to_use_direct_io = 1, index_granularity_bytes = 10635531, concurrent_part_removal_threshold = 6, allow_vertical_merges_from_compact_to_wide_parts = true, cache_populated_by_fetch = true, marks_compress_block_size = 78567, primary_key_compress_block_size = 19593), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa91e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1558: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291bc5ff 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291ac835 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000291c3415 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b382fc 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 15. asan_thread_start(void*) @ 0x000000000aa43059 16. ? @ 0x00007f35aab92ac3 17. ? @ 0x00007f35aac24850 2025.09.09 15:03:00.510418 [ 3612 ] {bbf34cb4-5278-4c2c-b531-3cd8a1c05871} TCPHandler: Code: 57. DB::Exception: Table test_15.t2 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa91e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1558: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291bc5ff 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291ac835 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000291c3415 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b382fc 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 15. asan_thread_start(void*) @ 0x000000000aa43059 16. ? @ 0x00007f35aab92ac3 17. ? @ 0x00007f35aac24850 2025.09.09 15:03:01.071371 [ 2854 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:03:01.142036 [ 2859 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:03:01.961620 [ 4023 ] {3d7dae33-c101-47c1-a000-03372f508351} executeQuery: Code: 107. DB::Exception: File /var/lib/clickhouse/user_files/data.jsonl doesn't exist. (FILE_DOESNT_EXIST) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:47740) (comment: 02222_create_table_without_columns_metadata.sh) (in query: select * from test_dist), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 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) @ 0x000000002b79db62 5. ./build_docker/./src/Planner/PlannerJoinTree.cpp:880: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x0000000029469c4b 6. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1795: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000002945d99d 7. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x000000002942c986 8. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x00000000294261fb 9. ./src/Planner/Planner.h:56: DB::InterpreterSelectQueryAnalyzer::extractQueryPlan() && @ 0x0000000029421592 10. ./build_docker/./src/Processors/QueryPlan/DistributedCreateLocalPlan.cpp:45: DB::createLocalPlan(std::shared_ptr const&, DB::Block const&, std::shared_ptr, DB::QueryProcessingStage::Enum, unsigned long, unsigned long, bool) @ 0x000000002dd8b9cb 11. ./build_docker/./src/Interpreters/ClusterProxy/SelectStreamFactory.cpp:161: DB::ClusterProxy::SelectStreamFactory::createForShardImpl(DB::Cluster::ShardInfo const&, std::shared_ptr const&, std::shared_ptr const&, DB::StorageID const&, std::shared_ptr const&, std::shared_ptr, std::vector>, std::allocator>>>&, std::vector>&, unsigned int, bool, std::function (unsigned long)>, bool)::$_0::operator()() const @ 0x000000002aac4d19 12. ./build_docker/./src/Interpreters/ClusterProxy/SelectStreamFactory.cpp:234: DB::ClusterProxy::SelectStreamFactory::createForShardImpl(DB::Cluster::ShardInfo const&, std::shared_ptr const&, std::shared_ptr const&, DB::StorageID const&, std::shared_ptr const&, std::shared_ptr, std::vector>, std::allocator>>>&, std::vector>&, unsigned int, bool, std::function (unsigned long)>, bool) @ 0x000000002aac1fe6 13. ./build_docker/./src/Interpreters/ClusterProxy/SelectStreamFactory.cpp:308: DB::ClusterProxy::SelectStreamFactory::createForShard(DB::Cluster::ShardInfo const&, std::shared_ptr const&, DB::StorageID const&, std::shared_ptr const&, std::shared_ptr, std::vector>, std::allocator>>>&, std::vector>&, unsigned int, bool, std::function (unsigned long)>) @ 0x000000002aac5412 14. ./build_docker/./src/Interpreters/ClusterProxy/executeQuery.cpp:333: DB::ClusterProxy::executeQuery(DB::QueryPlan&, DB::Block const&, DB::QueryProcessingStage::Enum, DB::StorageID const&, std::shared_ptr const&, DB::ClusterProxy::SelectStreamFactory&, std::shared_ptr, std::shared_ptr, DB::SelectQueryInfo const&, std::shared_ptr const&, String const&, DB::DistributedSettings const&, std::function (unsigned long)>, bool) @ 0x000000002aaa50f0 15. ./build_docker/./src/Storages/StorageDistributed.cpp:864: DB::StorageDistributed::read(DB::QueryPlan&, std::vector> const&, std::shared_ptr const&, DB::SelectQueryInfo&, std::shared_ptr, DB::QueryProcessingStage::Enum, unsigned long, unsigned long) @ 0x000000002b730b7f 16. ./build_docker/./src/Planner/PlannerJoinTree.cpp:880: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x0000000029469c4b 17. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1795: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000002945d99d 18. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x000000002942c986 19. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x00000000294261fb 20. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000029421552 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1182: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3737e 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 23. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 24. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 29. asan_thread_start(void*) @ 0x000000000aa43059 30. ? @ 0x00007f35aab92ac3 31. ? @ 0x00007f35aac24850 2025.09.09 15:03:01.975110 [ 4023 ] {3d7dae33-c101-47c1-a000-03372f508351} TCPHandler: Code: 107. DB::Exception: File /var/lib/clickhouse/user_files/data.jsonl 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 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) @ 0x000000002b79db62 5. ./build_docker/./src/Planner/PlannerJoinTree.cpp:880: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x0000000029469c4b 6. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1795: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000002945d99d 7. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x000000002942c986 8. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x00000000294261fb 9. ./src/Planner/Planner.h:56: DB::InterpreterSelectQueryAnalyzer::extractQueryPlan() && @ 0x0000000029421592 10. ./build_docker/./src/Processors/QueryPlan/DistributedCreateLocalPlan.cpp:45: DB::createLocalPlan(std::shared_ptr const&, DB::Block const&, std::shared_ptr, DB::QueryProcessingStage::Enum, unsigned long, unsigned long, bool) @ 0x000000002dd8b9cb 11. ./build_docker/./src/Interpreters/ClusterProxy/SelectStreamFactory.cpp:161: DB::ClusterProxy::SelectStreamFactory::createForShardImpl(DB::Cluster::ShardInfo const&, std::shared_ptr const&, std::shared_ptr const&, DB::StorageID const&, std::shared_ptr const&, std::shared_ptr, std::vector>, std::allocator>>>&, std::vector>&, unsigned int, bool, std::function (unsigned long)>, bool)::$_0::operator()() const @ 0x000000002aac4d19 12. ./build_docker/./src/Interpreters/ClusterProxy/SelectStreamFactory.cpp:234: DB::ClusterProxy::SelectStreamFactory::createForShardImpl(DB::Cluster::ShardInfo const&, std::shared_ptr const&, std::shared_ptr const&, DB::StorageID const&, std::shared_ptr const&, std::shared_ptr, std::vector>, std::allocator>>>&, std::vector>&, unsigned int, bool, std::function (unsigned long)>, bool) @ 0x000000002aac1fe6 13. ./build_docker/./src/Interpreters/ClusterProxy/SelectStreamFactory.cpp:308: DB::ClusterProxy::SelectStreamFactory::createForShard(DB::Cluster::ShardInfo const&, std::shared_ptr const&, DB::StorageID const&, std::shared_ptr const&, std::shared_ptr, std::vector>, std::allocator>>>&, std::vector>&, unsigned int, bool, std::function (unsigned long)>) @ 0x000000002aac5412 14. ./build_docker/./src/Interpreters/ClusterProxy/executeQuery.cpp:333: DB::ClusterProxy::executeQuery(DB::QueryPlan&, DB::Block const&, DB::QueryProcessingStage::Enum, DB::StorageID const&, std::shared_ptr const&, DB::ClusterProxy::SelectStreamFactory&, std::shared_ptr, std::shared_ptr, DB::SelectQueryInfo const&, std::shared_ptr const&, String const&, DB::DistributedSettings const&, std::function (unsigned long)>, bool) @ 0x000000002aaa50f0 15. ./build_docker/./src/Storages/StorageDistributed.cpp:864: DB::StorageDistributed::read(DB::QueryPlan&, std::vector> const&, std::shared_ptr const&, DB::SelectQueryInfo&, std::shared_ptr, DB::QueryProcessingStage::Enum, unsigned long, unsigned long) @ 0x000000002b730b7f 16. ./build_docker/./src/Planner/PlannerJoinTree.cpp:880: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x0000000029469c4b 17. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1795: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000002945d99d 18. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x000000002942c986 19. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x00000000294261fb 20. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000029421552 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1182: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3737e 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 23. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 24. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 29. asan_thread_start(void*) @ 0x000000000aa43059 30. ? @ 0x00007f35aab92ac3 31. ? @ 0x00007f35aac24850 2025.09.09 15:03:02.073778 [ 2873 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:03:02.144371 [ 2876 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:03:02.768460 [ 4023 ] {9675fa73-a88c-4ca4-8e2e-6c1731a413db} executeQuery: Code: 57. DB::Exception: Table test_3.foo already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:47744) (comment: 01011_test_create_as_skip_indices.sql) (in query: CREATE TABLE foo (`key` int, INDEX i1 key TYPE minmax GRANULARITY 1) ENGINE = MergeTree ORDER BY key SETTINGS index_granularity = 50226, min_bytes_for_wide_part = 1073741824, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = true, max_file_name_length = 46, min_bytes_for_full_part_storage = 536870912, compact_parts_max_bytes_to_buffer = 380145319, compact_parts_max_granules_to_buffer = 197, compact_parts_merge_max_bytes_to_prefetch_part = 23941044, merge_max_block_size = 6043, old_parts_lifetime = 280., 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 = 4947575625, index_granularity_bytes = 21070200, concurrent_part_removal_threshold = 59, allow_vertical_merges_from_compact_to_wide_parts = true, cache_populated_by_fetch = false, marks_compress_block_size = 78191, primary_key_compress_block_size = 85016), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa91e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1558: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291bc5ff 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291ac835 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000291c3415 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b382fc 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 15. asan_thread_start(void*) @ 0x000000000aa43059 16. ? @ 0x00007f35aab92ac3 17. ? @ 0x00007f35aac24850 2025.09.09 15:03:02.782346 [ 4023 ] {9675fa73-a88c-4ca4-8e2e-6c1731a413db} TCPHandler: Code: 57. DB::Exception: Table test_3.foo already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa91e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1558: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291bc5ff 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291ac835 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000291c3415 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b382fc 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 15. asan_thread_start(void*) @ 0x000000000aa43059 16. ? @ 0x00007f35aab92ac3 17. ? @ 0x00007f35aac24850 2025.09.09 15:03:03.076351 [ 2896 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:03:03.146479 [ 2898 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:03:04.079548 [ 2917 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:03:04.149283 [ 2902 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:03:05.000006 [ 4023 ] {9cc5d333-ae1f-4103-9e2a-39fd9de696da} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=773, jobs=735). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:47774) (comment: 02009_from_infile.sh) (in query: SELECT * FROM test_infile;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af872f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af7b2d1 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af7c3f3 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d36920d 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000002d369e5f 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processOrdinaryQuery() @ 0x000000002d18af7b 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d17644a 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 15. asan_thread_start(void*) @ 0x000000000aa43059 16. ? @ 0x00007f35aab92ac3 17. ? @ 0x00007f35aac24850 2025.09.09 15:03:05.021255 [ 4023 ] {9cc5d333-ae1f-4103-9e2a-39fd9de696da} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=773, 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af872f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af7b2d1 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af7c3f3 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d36920d 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000002d369e5f 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processOrdinaryQuery() @ 0x000000002d18af7b 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d17644a 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 15. asan_thread_start(void*) @ 0x000000000aa43059 16. ? @ 0x00007f35aab92ac3 17. ? @ 0x00007f35aac24850 2025.09.09 15:03:05.081703 [ 2931 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:03:05.153690 [ 2933 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:03:06.086431 [ 2949 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:03:06.157276 [ 2948 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:03:07.088697 [ 2964 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:03:07.159778 [ 2963 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:03:08.091475 [ 2984 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:03:08.162665 [ 2997 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:03:09.094734 [ 3013 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:03:09.165909 [ 3018 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:03:10.101439 [ 3033 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:03:10.169606 [ 3031 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:03:10.452842 [ 4022 ] {de8fb1e2-e599-4574-a93c-e57611f0d033} executeQuery: Code: 210. DB::NetException: Connection reset by peer, while writing to socket ([::ffff:127.0.0.5]:9000 -> [::ffff:127.0.0.1]:41934). (NETWORK_ERROR) (version 24.8.14.10505.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:41934) (comment: 02340_parts_refcnt_mergetree.sh) (in query: SELECT sleepEachRow(0.1) AS `sleepEachRow(0.1)` FROM `test_3`.`data_02340` AS `__table1` WHERE `__table1`.`part` = 1), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 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&&) @ 0x000000001b0b7a5f 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:158: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000001b0bab02 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:201: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000002cf09bf7 5. ./src/IO/WriteBuffer.h:66: DB::TCPHandler::sendData(DB::Block const&) @ 0x000000002d190f6b 6. ./contrib/llvm-project/libcxx/include/__hash_table:1473: DB::TCPHandler::processOrdinaryQuery() @ 0x000000002d18b989 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d17644a 8. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 12. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 13. asan_thread_start(void*) @ 0x000000000aa43059 14. ? @ 0x00007f35aab92ac3 15. ? @ 0x00007f35aac24850 2025.09.09 15:03:10.456399 [ 4022 ] {de8fb1e2-e599-4574-a93c-e57611f0d033} TCPHandler: Can't send logs to client: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::ffff:127.0.0.5]:9000 -> [::ffff:127.0.0.1]:41934). (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 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&&) @ 0x000000001b0b7a5f 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:169: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000001b0bada2 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:201: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000002cf09bf7 5. ./src/IO/WriteBuffer.h:66: DB::TCPHandler::sendLogData(DB::Block const&) @ 0x000000002d1a9beb 6. ./contrib/llvm-project/libcxx/include/__hash_table:1473: DB::TCPHandler::sendLogs() @ 0x000000002d18db59 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d176902 8. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 12. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 13. asan_thread_start(void*) @ 0x000000000aa43059 14. ? @ 0x00007f35aab92ac3 15. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:03:10.457828 [ 4022 ] {de8fb1e2-e599-4574-a93c-e57611f0d033} TCPHandler: Code: 210. DB::NetException: Connection reset by peer, while writing to socket ([::ffff:127.0.0.5]:9000 -> [::ffff:127.0.0.1]:41934). (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 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&&) @ 0x000000001b0b7a5f 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:158: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000001b0bab02 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:201: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000002cf09bf7 5. ./src/IO/WriteBuffer.h:66: DB::TCPHandler::sendData(DB::Block const&) @ 0x000000002d190f6b 6. ./contrib/llvm-project/libcxx/include/__hash_table:1473: DB::TCPHandler::processOrdinaryQuery() @ 0x000000002d18b989 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d17644a 8. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 12. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 13. asan_thread_start(void*) @ 0x000000000aa43059 14. ? @ 0x00007f35aab92ac3 15. ? @ 0x00007f35aac24850 2025.09.09 15:03:10.459420 [ 4022 ] {de8fb1e2-e599-4574-a93c-e57611f0d033} TCPHandler: Client has gone away. 2025.09.09 15:03:11.112231 [ 3059 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:03:11.172603 [ 3064 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:03:12.115102 [ 3090 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:03:12.175367 [ 3088 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:03:13.118478 [ 3117 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:03:13.178211 [ 3115 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:03:14.121554 [ 3137 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:03:14.181839 [ 3150 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:03:14.421390 [ 3151 ] {} test_3.data_02340_rep (624c1f74-0774-46b4-8cc8-f9961b20efc5): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 236. DB::Exception: Log pulling is cancelled. (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aac868e 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:623: DB::ReplicatedMergeTreeQueue::pullLogsToQueue(std::shared_ptr, std::function, DB::ReplicatedMergeTreeQueue::PullLogsReason) @ 0x000000002ca80238 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002baf68ec 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:03:15.124557 [ 3175 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:03:15.184938 [ 3179 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:03:15.427397 [ 3182 ] {} test_3.data_02340_rep (624c1f74-0774-46b4-8cc8-f9961b20efc5): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 236. DB::Exception: Log pulling is cancelled. (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aac868e 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:623: DB::ReplicatedMergeTreeQueue::pullLogsToQueue(std::shared_ptr, std::function, DB::ReplicatedMergeTreeQueue::PullLogsReason) @ 0x000000002ca80238 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002baf68ec 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:03:16.127523 [ 3202 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:03:16.188146 [ 3197 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:03:16.431160 [ 3206 ] {} test_3.data_02340_rep (624c1f74-0774-46b4-8cc8-f9961b20efc5): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 236. DB::Exception: Log pulling is cancelled. (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aac868e 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:623: DB::ReplicatedMergeTreeQueue::pullLogsToQueue(std::shared_ptr, std::function, DB::ReplicatedMergeTreeQueue::PullLogsReason) @ 0x000000002ca80238 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002baf68ec 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:03:17.131206 [ 3233 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:03:17.191209 [ 3218 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:03:17.434090 [ 3237 ] {} test_3.data_02340_rep (624c1f74-0774-46b4-8cc8-f9961b20efc5): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 236. DB::Exception: Log pulling is cancelled. (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aac868e 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:623: DB::ReplicatedMergeTreeQueue::pullLogsToQueue(std::shared_ptr, std::function, DB::ReplicatedMergeTreeQueue::PullLogsReason) @ 0x000000002ca80238 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002baf68ec 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:03:17.773585 [ 3604 ] {e8e73b66-7cfa-4990-8892-779aca1930dc} executeQuery: Code: 210. DB::NetException: Connection reset by peer, while writing to socket ([::ffff:127.0.0.9]:9000 -> [::ffff:127.0.0.1]:39214). (NETWORK_ERROR) (version 24.8.14.10505.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:39214) (comment: 02340_parts_refcnt_mergetree.sh) (in query: SELECT sleepEachRow(0.1) AS `sleepEachRow(0.1)` FROM `test_3`.`data_02340_rep` AS `__table1` WHERE `__table1`.`part` = 1), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 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&&) @ 0x000000001b0b7a5f 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:158: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000001b0bab02 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:201: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000002cf09bf7 5. ./src/IO/WriteBuffer.h:66: DB::TCPHandler::sendData(DB::Block const&) @ 0x000000002d190f6b 6. ./contrib/llvm-project/libcxx/include/__hash_table:1473: DB::TCPHandler::processOrdinaryQuery() @ 0x000000002d18b989 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d17644a 8. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 12. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 13. asan_thread_start(void*) @ 0x000000000aa43059 14. ? @ 0x00007f35aab92ac3 15. ? @ 0x00007f35aac24850 2025.09.09 15:03:17.776667 [ 3604 ] {e8e73b66-7cfa-4990-8892-779aca1930dc} TCPHandler: Can't send logs to client: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::ffff:127.0.0.9]:9000 -> [::ffff:127.0.0.1]:39214). (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 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&&) @ 0x000000001b0b7a5f 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:169: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000001b0bada2 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:201: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000002cf09bf7 5. ./src/IO/WriteBuffer.h:66: DB::TCPHandler::sendLogData(DB::Block const&) @ 0x000000002d1a9beb 6. ./contrib/llvm-project/libcxx/include/__hash_table:1473: DB::TCPHandler::sendLogs() @ 0x000000002d18db59 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d176902 8. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 12. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 13. asan_thread_start(void*) @ 0x000000000aa43059 14. ? @ 0x00007f35aab92ac3 15. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:03:17.777625 [ 3604 ] {e8e73b66-7cfa-4990-8892-779aca1930dc} TCPHandler: Code: 210. DB::NetException: Connection reset by peer, while writing to socket ([::ffff:127.0.0.9]:9000 -> [::ffff:127.0.0.1]:39214). (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 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&&) @ 0x000000001b0b7a5f 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:158: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000001b0bab02 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:201: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000002cf09bf7 5. ./src/IO/WriteBuffer.h:66: DB::TCPHandler::sendData(DB::Block const&) @ 0x000000002d190f6b 6. ./contrib/llvm-project/libcxx/include/__hash_table:1473: DB::TCPHandler::processOrdinaryQuery() @ 0x000000002d18b989 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d17644a 8. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 12. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 13. asan_thread_start(void*) @ 0x000000000aa43059 14. ? @ 0x00007f35aab92ac3 15. ? @ 0x00007f35aac24850 2025.09.09 15:03:17.779147 [ 3604 ] {e8e73b66-7cfa-4990-8892-779aca1930dc} TCPHandler: Client has gone away. 2025.09.09 15:03:18.112337 [ 3604 ] {ec712a74-2860-4030-8493-a03cc6b19c09} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=773, jobs=735). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:57292) (comment: 01710_normal_projections.sh) (in query: SELECT * FROM test_sort_proj WHERE x < 10 order by x SETTINGS optimize_move_to_prewhere = 1, optimize_use_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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af872f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af7b2d1 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af7c3f3 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d36920d 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000002d369e5f 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processOrdinaryQuery() @ 0x000000002d18af7b 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d17644a 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 15. asan_thread_start(void*) @ 0x000000000aa43059 16. ? @ 0x00007f35aab92ac3 17. ? @ 0x00007f35aac24850 2025.09.09 15:03:18.125948 [ 3604 ] {ec712a74-2860-4030-8493-a03cc6b19c09} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=773, 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af872f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af7b2d1 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af7c3f3 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d36920d 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000002d369e5f 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processOrdinaryQuery() @ 0x000000002d18af7b 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d17644a 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 15. asan_thread_start(void*) @ 0x000000000aa43059 16. ? @ 0x00007f35aab92ac3 17. ? @ 0x00007f35aac24850 2025.09.09 15:03:18.134218 [ 2750 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:03:18.194225 [ 2734 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:03:18.438004 [ 2736 ] {} test_3.data_02340_rep (624c1f74-0774-46b4-8cc8-f9961b20efc5): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 236. DB::Exception: Log pulling is cancelled. (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aac868e 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:623: DB::ReplicatedMergeTreeQueue::pullLogsToQueue(std::shared_ptr, std::function, DB::ReplicatedMergeTreeQueue::PullLogsReason) @ 0x000000002ca80238 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002baf68ec 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:03:19.144018 [ 2761 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:03:19.197458 [ 2765 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:03:20.146524 [ 2777 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:03:20.200449 [ 2774 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:03:21.151714 [ 2802 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:03:21.202663 [ 2791 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:03:21.459241 [ 4025 ] {9f8cd9cd-5fc7-470a-9cb2-0d9a8f9d5120} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=0, jobs=0). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:44894) (comment: 00615_nullable_alter_optimize.sql) (in query: SELECT `__table1`.`dt` AS `dt`, `__table1`.`id` AS `id`, `__table1`.`key` AS `key`, `__table1`.`data` AS `data` FROM `test_3`.`test_00615` AS `__table1` ORDER BY `__table1`.`data` ASC NULLS FIRST), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af80b71 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af82f33 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002c64fc80 7. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1723: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr, unsigned long, std::shared_ptr, std::equal_to, std::allocator>>>, DB::MergeTreeData const&, std::vector> const&, std::shared_ptr, std::optional&, bool) @ 0x000000002de379fd 8. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1437: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000002de3554f 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:0: DB::ReadFromMergeTree::getAnalysisResult() const @ 0x000000002de41345 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:2022: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000002de4404c 11. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000002ddb933c 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000002ddff11e 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000002942117f 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x00000000294209e7 15. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b382fc 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 18. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 22. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:03:21.463855 [ 4025 ] {9f8cd9cd-5fc7-470a-9cb2-0d9a8f9d5120} 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af80b71 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af82f33 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002c64fc80 7. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1723: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr, unsigned long, std::shared_ptr, std::equal_to, std::allocator>>>, DB::MergeTreeData const&, std::vector> const&, std::shared_ptr, std::optional&, bool) @ 0x000000002de379fd 8. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1437: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000002de3554f 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:0: DB::ReadFromMergeTree::getAnalysisResult() const @ 0x000000002de41345 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:2022: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000002de4404c 11. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000002ddb933c 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000002ddff11e 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000002942117f 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x00000000294209e7 15. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b382fc 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 18. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 22. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:03:21.540210 [ 3612 ] {b8c216c2-6caf-48e0-b5d1-09fc2d3f8bf8} executeQuery: Code: 439. DB::Exception: Received from 127.0.0.6:9000. DB::Exception: Cannot schedule a task: fault injected (threads=0, jobs=0). Stack trace: 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af80b71 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af82f33 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002c64fc80 7. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1723: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr, unsigned long, std::shared_ptr, std::equal_to, std::allocator>>>, DB::MergeTreeData const&, std::vector> const&, std::shared_ptr, std::optional&, bool) @ 0x000000002de379fd 8. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1437: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000002de3554f 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:0: DB::ReadFromMergeTree::getAnalysisResult() const @ 0x000000002de41345 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:2022: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000002de4404c 11. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000002ddb933c 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000002ddff11e 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000002942117f 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x00000000294209e7 15. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b382fc 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 18. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 22. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 : While executing Remote. (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:34452) (comment: 00615_nullable_alter_optimize.sql) (in query: SELECT * FROM test_00615 ORDER BY data NULLS FIRST;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. ./contrib/llvm-project/libcxx/include/string:1499: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x000000001aeb974e 3. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::Connection::receiveException() const @ 0x000000002cee6c6a 4. ./build_docker/./src/Client/Connection.cpp:0: DB::Connection::receivePacket() @ 0x000000002cef780e 5. ./build_docker/./src/Client/MultiplexedConnections.cpp:340: DB::MultiplexedConnections::receivePacketUnlocked(std::function) @ 0x000000002cf8e09e 6. ./build_docker/./src/QueryPipeline/RemoteQueryExecutorReadContext.cpp:0: DB::RemoteQueryExecutorReadContext::Task::run(std::function, std::function) @ 0x00000000278ad616 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000278ab436 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000278aaa44 9. ./contrib/boost/boost/context/fiber_ucontext.hpp:82: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x00000000278a8394 2025.09.09 15:03:21.575464 [ 3612 ] {b8c216c2-6caf-48e0-b5d1-09fc2d3f8bf8} TCPHandler: Code: 439. DB::Exception: Received from 127.0.0.6:9000. DB::Exception: Cannot schedule a task: fault injected (threads=0, jobs=0). Stack trace: 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af80b71 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af82f33 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002c64fc80 7. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1723: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr, unsigned long, std::shared_ptr, std::equal_to, std::allocator>>>, DB::MergeTreeData const&, std::vector> const&, std::shared_ptr, std::optional&, bool) @ 0x000000002de379fd 8. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1437: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000002de3554f 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:0: DB::ReadFromMergeTree::getAnalysisResult() const @ 0x000000002de41345 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:2022: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000002de4404c 11. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000002ddb933c 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000002ddff11e 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000002942117f 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x00000000294209e7 15. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b382fc 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 18. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 22. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 : 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. ./contrib/llvm-project/libcxx/include/string:1499: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x000000001aeb974e 3. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::Connection::receiveException() const @ 0x000000002cee6c6a 4. ./build_docker/./src/Client/Connection.cpp:0: DB::Connection::receivePacket() @ 0x000000002cef780e 5. ./build_docker/./src/Client/MultiplexedConnections.cpp:340: DB::MultiplexedConnections::receivePacketUnlocked(std::function) @ 0x000000002cf8e09e 6. ./build_docker/./src/QueryPipeline/RemoteQueryExecutorReadContext.cpp:0: DB::RemoteQueryExecutorReadContext::Task::run(std::function, std::function) @ 0x00000000278ad616 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000278ab436 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000278aaa44 9. ./contrib/boost/boost/context/fiber_ucontext.hpp:82: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x00000000278a8394 2025.09.09 15:03:21.648881 [ 2688 ] {dd6d479f-6ff5-458a-b13d-7f24864f4902} executeQuery: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::ffff:127.0.0.10]:9000 -> [::ffff:127.0.0.1]:36574). (NETWORK_ERROR) (version 24.8.14.10505.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:36574) (comment: 00615_nullable_alter_optimize.sql) (in query: SELECT `__table1`.`dt` AS `dt`, `__table1`.`id` AS `id`, `__table1`.`key` AS `key`, `__table1`.`data` AS `data` FROM `test_3`.`test_00615` AS `__table1` ORDER BY `__table1`.`data` ASC NULLS FIRST), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 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&&) @ 0x000000001b0b7a5f 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:169: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000001b0bada2 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:201: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000002cf09bf7 5. ./src/IO/WriteBuffer.h:66: DB::TCPHandler::sendData(DB::Block const&) @ 0x000000002d190f6b 6. ./contrib/llvm-project/libcxx/include/__hash_table:1473: DB::TCPHandler::processOrdinaryQuery() @ 0x000000002d18b989 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d17644a 8. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 12. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 13. asan_thread_start(void*) @ 0x000000000aa43059 14. ? @ 0x00007f35aab92ac3 15. ? @ 0x00007f35aac24850 2025.09.09 15:03:21.658087 [ 2688 ] {dd6d479f-6ff5-458a-b13d-7f24864f4902} TCPHandler: Can't send logs to client: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::ffff:127.0.0.10]:9000 -> [::ffff:127.0.0.1]:36574). (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 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&&) @ 0x000000001b0b7a5f 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:169: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000001b0bada2 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:201: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000002cf09bf7 5. ./src/IO/WriteBuffer.h:66: DB::TCPHandler::sendLogData(DB::Block const&) @ 0x000000002d1a9beb 6. ./contrib/llvm-project/libcxx/include/__hash_table:1473: DB::TCPHandler::sendLogs() @ 0x000000002d18db59 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d176902 8. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 12. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 13. asan_thread_start(void*) @ 0x000000000aa43059 14. ? @ 0x00007f35aab92ac3 15. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:03:21.660115 [ 2688 ] {dd6d479f-6ff5-458a-b13d-7f24864f4902} TCPHandler: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::ffff:127.0.0.10]:9000 -> [::ffff:127.0.0.1]:36574). (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 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&&) @ 0x000000001b0b7a5f 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:169: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000001b0bada2 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:201: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000002cf09bf7 5. ./src/IO/WriteBuffer.h:66: DB::TCPHandler::sendData(DB::Block const&) @ 0x000000002d190f6b 6. ./contrib/llvm-project/libcxx/include/__hash_table:1473: DB::TCPHandler::processOrdinaryQuery() @ 0x000000002d18b989 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d17644a 8. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 12. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 13. asan_thread_start(void*) @ 0x000000000aa43059 14. ? @ 0x00007f35aab92ac3 15. ? @ 0x00007f35aac24850 2025.09.09 15:03:21.663118 [ 2688 ] {dd6d479f-6ff5-458a-b13d-7f24864f4902} TCPHandler: Client has gone away. 2025.09.09 15:03:22.154578 [ 2826 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:03:22.205195 [ 2819 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:03:23.157466 [ 2862 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:03:23.208243 [ 2864 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:03:24.160780 [ 2909 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:03:24.210238 [ 2906 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:03:25.169835 [ 2968 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:03:25.212591 [ 2963 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:03:26.175085 [ 3020 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:03:26.215315 [ 3036 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:03:27.177469 [ 3100 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:03:27.217758 [ 3103 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:03:28.180433 [ 3137 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:03:28.220276 [ 3146 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:03:28.705674 [ 3337 ] {0c1ccd6f-b00a-40c1-b841-8cc77c811ec4::all_1_1_0_2} MutatePlainMergeTreeTask: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=773, jobs=735). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:03:28.710988 [ 3612 ] {a34591f7-637d-46dc-ad16-0ac1530978f0} 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=773, jobs=735). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.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.10505.altinitytest (altinity build)) (from [::1]:51946) (comment: 01710_normal_projections.sh) (in query: ALTER TABLE test_sort_proj DELETE WHERE x % 2 = 0 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&&, String&, String&) @ 0x000000002c76d4c6 4. ./build_docker/./src/Storages/MergeTree/MergeTreeMutationStatus.cpp:26: DB::checkMutationStatus(std::optional&, std::set, std::allocator> const&) @ 0x000000002c76d210 5. ./build_docker/./src/Storages/StorageMergeTree.cpp:0: DB::StorageMergeTree::waitForMutation(long, String const&, bool) @ 0x000000002cbbc805 6. ./contrib/llvm-project/libcxx/include/string:1499: DB::StorageMergeTree::mutate(DB::MutationCommands const&, std::shared_ptr) @ 0x000000002cbbe409 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000029174a1c 8. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x0000000029170711 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b382fc 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 15:03:28.715202 [ 3612 ] {a34591f7-637d-46dc-ad16-0ac1530978f0} 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=773, jobs=735). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&&, String&, String&) @ 0x000000002c76d4c6 4. ./build_docker/./src/Storages/MergeTree/MergeTreeMutationStatus.cpp:26: DB::checkMutationStatus(std::optional&, std::set, std::allocator> const&) @ 0x000000002c76d210 5. ./build_docker/./src/Storages/StorageMergeTree.cpp:0: DB::StorageMergeTree::waitForMutation(long, String const&, bool) @ 0x000000002cbbc805 6. ./contrib/llvm-project/libcxx/include/string:1499: DB::StorageMergeTree::mutate(DB::MutationCommands const&, std::shared_ptr) @ 0x000000002cbbe409 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000029174a1c 8. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x0000000029170711 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b382fc 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 15:03:28.780480 [ 3337 ] {0c1ccd6f-b00a-40c1-b841-8cc77c811ec4::all_1_1_0_2} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=773, 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af872f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af7b2d1 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af7c3f3 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d36920d 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000002d369e5f 8. ./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) @ 0x000000002959299a 9. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:2185: DB::MutateTask::prepare() @ 0x000000002c9098ab 10. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:2054: DB::MutateTask::execute() @ 0x000000002c907b70 11. ./build_docker/./src/Storages/MergeTree/MutatePlainMergeTreeTask.cpp:91: DB::MutatePlainMergeTreeTask::executeStep() @ 0x000000002cc3501a 12. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000002c427f28 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000002c429675 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7eaf0 15. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001af8a79f 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 18. asan_thread_start(void*) @ 0x000000000aa43059 19. ? @ 0x00007f35aab92ac3 20. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:03:29.182493 [ 3178 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:03:29.222291 [ 3177 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:03:29.706101 [ 3604 ] {7d144618-01bd-49f4-b4a8-77c0086bb08e} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=9, jobs=0): (while reading column ProfileEvents): (while reading from part /var/lib/clickhouse/store/108/108b9aab-fe65-4ab9-8855-f1d393dc8a98/202509_62_62_0/ in table system.part_log (108b9aab-fe65-4ab9-8855-f1d393dc8a98) located on disk default of type local, from mark 0 with max_rows_to_read = 34): While executing MergeTreeSelect(pool: ReadPoolParallelReplicas, algorithm: Thread). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:34490) (comment: 02378_part_log_profile_events_replicated.sql) (in query: SELECT count() > 1 AND SUM(ProfileEvents['ZooKeeperTransactions']) >= 4 FROM system.part_log WHERE event_time > now() - INTERVAL 10 MINUTE AND database == currentDatabase() AND table == 'part_log_profile_events_r2' AND event_type == 'DownloadPart' ;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af80b71 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80746 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000266005a2 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000265fffb4 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:1197: ? @ 0x00000000265fd4e7 9. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:62: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x00000000265e6fbd 10. ./contrib/llvm-project/libcxx/include/future:1123: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x00000000265e7bb3 11. DB::ReadBuffer::next() @ 0x000000000b528aeb 12. ./src/IO/ReadBuffer.h:0: DB::CompressedReadBufferBase::readCompressedData(unsigned long&, unsigned long&, bool) @ 0x000000002775f11b 13. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:22: DB::CompressedReadBufferFromFile::nextImpl() @ 0x0000000027763d41 14. DB::ReadBuffer::next() @ 0x000000000b528aeb 15. ./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 @ 0x0000000027ab9e45 16. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:0: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x000000002c7b254b 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7eb79e 18. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:118: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7c9d8a 19. ./src/Storages/MergeTree/MergeTreeRangeReader.h:139: DB::MergeTreeRangeReader::continueReadingChain(DB::MergeTreeRangeReader::ReadResult const&, unsigned long&) @ 0x000000002c7df38d 20. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:984: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x000000002c7dbd9d 21. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:0: DB::MergeTreeReadTask::read(DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002c82d05b 22. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:38: DB::MergeTreeThreadSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&, DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002de66094 23. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:0: DB::MergeTreeSelectProcessor::read() @ 0x000000002c8242f9 24. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000002de6d77a 25. ./build_docker/./src/Processors/ISource.cpp:0: DB::ISource::work() @ 0x000000002d3290a1 26. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 27. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 28. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000002d34877c 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000002d34827b 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*) @ 0x000000002d36bcf7 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 2025.09.09 15:03:29.721674 [ 3604 ] {7d144618-01bd-49f4-b4a8-77c0086bb08e} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=9, jobs=0): (while reading column ProfileEvents): (while reading from part /var/lib/clickhouse/store/108/108b9aab-fe65-4ab9-8855-f1d393dc8a98/202509_62_62_0/ in table system.part_log (108b9aab-fe65-4ab9-8855-f1d393dc8a98) located on disk default of type local, from mark 0 with max_rows_to_read = 34): While executing MergeTreeSelect(pool: ReadPoolParallelReplicas, algorithm: Thread). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af80b71 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80746 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000266005a2 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000265fffb4 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:1197: ? @ 0x00000000265fd4e7 9. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:62: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x00000000265e6fbd 10. ./contrib/llvm-project/libcxx/include/future:1123: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x00000000265e7bb3 11. DB::ReadBuffer::next() @ 0x000000000b528aeb 12. ./src/IO/ReadBuffer.h:0: DB::CompressedReadBufferBase::readCompressedData(unsigned long&, unsigned long&, bool) @ 0x000000002775f11b 13. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:22: DB::CompressedReadBufferFromFile::nextImpl() @ 0x0000000027763d41 14. DB::ReadBuffer::next() @ 0x000000000b528aeb 15. ./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 @ 0x0000000027ab9e45 16. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:0: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x000000002c7b254b 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7eb79e 18. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:118: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7c9d8a 19. ./src/Storages/MergeTree/MergeTreeRangeReader.h:139: DB::MergeTreeRangeReader::continueReadingChain(DB::MergeTreeRangeReader::ReadResult const&, unsigned long&) @ 0x000000002c7df38d 20. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:984: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x000000002c7dbd9d 21. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:0: DB::MergeTreeReadTask::read(DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002c82d05b 22. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:38: DB::MergeTreeThreadSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&, DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002de66094 23. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:0: DB::MergeTreeSelectProcessor::read() @ 0x000000002c8242f9 24. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000002de6d77a 25. ./build_docker/./src/Processors/ISource.cpp:0: DB::ISource::work() @ 0x000000002d3290a1 26. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 27. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 28. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000002d34877c 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000002d34827b 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*) @ 0x000000002d36bcf7 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 2025.09.09 15:03:30.184931 [ 3203 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:03:30.226404 [ 3206 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:03:31.188065 [ 3237 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:03:31.230373 [ 3224 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:03:32.191177 [ 2751 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:03:32.233367 [ 2743 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:03:33.193611 [ 2766 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:03:33.235854 [ 2771 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:03:34.196506 [ 2797 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:03:34.238900 [ 2786 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:03:35.198948 [ 2805 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:03:35.241284 [ 2816 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:03:36.201796 [ 2839 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:03:36.243482 [ 2849 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:03:37.203681 [ 2877 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:03:37.246384 [ 2875 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:03:38.206249 [ 2893 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:03:38.249508 [ 2900 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:03:39.211493 [ 2964 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:03:39.258916 [ 2969 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:03:40.215146 [ 2998 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:03:40.262133 [ 2990 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:03:41.262684 [ 3005 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:03:41.265495 [ 3021 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:03:42.268613 [ 3019 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:03:42.271614 [ 3023 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:03:43.273169 [ 3050 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:03:43.275372 [ 3060 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:03:44.275218 [ 3043 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:03:44.277729 [ 3076 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:03:45.342838 [ 3098 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:03:45.343808 [ 3103 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:03:46.345771 [ 3121 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:03:46.346822 [ 3117 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:03:47.357842 [ 3126 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:03:47.358628 [ 3130 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:03:48.370219 [ 3150 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:03:48.375089 [ 3137 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:03:49.372520 [ 3149 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:03:49.395836 [ 3173 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:03:49.455520 [ 3604 ] {9cf82c63-0366-48d0-9162-c7191d3f84b1} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=1, jobs=1). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:36810) (comment: 00162_mmap_compression_none.sql) (in query: SELECT sum(length(Title)) FROM hits_none;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af80b71 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80746 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d34b5ca 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000002d3486e4 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000002d34827b 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002d36bcf7 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 12. asan_thread_start(void*) @ 0x000000000aa43059 13. ? @ 0x00007f35aab92ac3 14. ? @ 0x00007f35aac24850 2025.09.09 15:03:49.462790 [ 3604 ] {9cf82c63-0366-48d0-9162-c7191d3f84b1} 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af80b71 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80746 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d34b5ca 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000002d3486e4 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000002d34827b 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002d36bcf7 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 12. asan_thread_start(void*) @ 0x000000000aa43059 13. ? @ 0x00007f35aab92ac3 14. ? @ 0x00007f35aac24850 2025.09.09 15:03:50.289351 [ 3612 ] {0bbb3cb4-feb4-4bec-bdf8-49e563ba79ec} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=13, jobs=1): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:53520) (comment: 02021_map_bloom_filter_index.sql) (in query: SELECT * FROM map_test_index_map_keys WHERE map['K2'] != 'V2' SETTINGS force_data_skipping_indices='map_bloom_filter_keys';), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af80b71 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80746 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002c765aab 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:1197: ? @ 0x000000002c7602b8 8. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x000000002c75fc2b 9. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:0: DB::MergeTreeReaderWide::addStream(DB::ISerialization::SubstreamPath const&, String const&) @ 0x000000002c802c31 10. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:0: void std::__function::__policy_invoker::__call_impl const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x000000002c804a95 11. ./src/DataTypes/Serializations/ISerialization.h:225: DB::SerializationArray::enumerateStreams(DB::ISerialization::EnumerateStreamsSettings&, std::function const&, DB::ISerialization::SubstreamData const&) const @ 0x0000000027ab5907 12. ./build_docker/./src/DataTypes/Serializations/SerializationMap.cpp:405: DB::SerializationMap::enumerateStreams(DB::ISerialization::EnumerateStreamsSettings&, std::function const&, DB::ISerialization::SubstreamData const&) const @ 0x0000000027b729b3 13. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:106: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x0000000027a9ea65 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:100: DB::MergeTreeReaderWide::addStreams(DB::NameAndTypePair const&, std::shared_ptr const&) @ 0x000000002c7fe815 15. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:0: DB::MergeTreeReaderWide::MergeTreeReaderWide(std::shared_ptr, DB::NamesAndTypesList, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*, DB::MarkCache*, DB::MarkRanges, DB::MergeTreeReaderSettings, std::map, std::allocator>>, std::function const&, int) @ 0x000000002c7fdeea 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) @ 0x000000002c5eb9c6 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 @ 0x000000002c5e354e 18. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:44: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x000000002c82acda 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:295: DB::MergeTreeReadPoolBase::createTask(std::shared_ptr, DB::MarkRanges, DB::MergeTreeReadTask*) const @ 0x000000002de9c234 20. ./build_docker/./src/Storages/MergeTree/MergeTreeReadPoolInOrder.cpp:72: DB::MergeTreeReadPoolInOrder::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x000000002deff671 21. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectAlgorithms.cpp:17: DB::MergeTreeInOrderSelectAlgorithm::getNewTask(DB::IMergeTreeReadPool&, DB::MergeTreeReadTask*) @ 0x000000002dea3919 22. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:0: DB::MergeTreeSelectProcessor::read() @ 0x000000002c8241d2 23. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000002de6d77a 24. ./build_docker/./src/Processors/ISource.cpp:0: DB::ISource::work() @ 0x000000002d3290a1 25. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 26. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 27. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000002d34877c 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000002d34827b 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*) @ 0x000000002d36bcf7 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 2025.09.09 15:03:50.373397 [ 3612 ] {0bbb3cb4-feb4-4bec-bdf8-49e563ba79ec} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=13, jobs=1): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af80b71 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80746 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002c765aab 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:1197: ? @ 0x000000002c7602b8 8. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x000000002c75fc2b 9. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:0: DB::MergeTreeReaderWide::addStream(DB::ISerialization::SubstreamPath const&, String const&) @ 0x000000002c802c31 10. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:0: void std::__function::__policy_invoker::__call_impl const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x000000002c804a95 11. ./src/DataTypes/Serializations/ISerialization.h:225: DB::SerializationArray::enumerateStreams(DB::ISerialization::EnumerateStreamsSettings&, std::function const&, DB::ISerialization::SubstreamData const&) const @ 0x0000000027ab5907 12. ./build_docker/./src/DataTypes/Serializations/SerializationMap.cpp:405: DB::SerializationMap::enumerateStreams(DB::ISerialization::EnumerateStreamsSettings&, std::function const&, DB::ISerialization::SubstreamData const&) const @ 0x0000000027b729b3 13. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:106: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x0000000027a9ea65 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:100: DB::MergeTreeReaderWide::addStreams(DB::NameAndTypePair const&, std::shared_ptr const&) @ 0x000000002c7fe815 15. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:0: DB::MergeTreeReaderWide::MergeTreeReaderWide(std::shared_ptr, DB::NamesAndTypesList, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*, DB::MarkCache*, DB::MarkRanges, DB::MergeTreeReaderSettings, std::map, std::allocator>>, std::function const&, int) @ 0x000000002c7fdeea 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) @ 0x000000002c5eb9c6 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 @ 0x000000002c5e354e 18. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:44: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x000000002c82acda 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:295: DB::MergeTreeReadPoolBase::createTask(std::shared_ptr, DB::MarkRanges, DB::MergeTreeReadTask*) const @ 0x000000002de9c234 20. ./build_docker/./src/Storages/MergeTree/MergeTreeReadPoolInOrder.cpp:72: DB::MergeTreeReadPoolInOrder::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x000000002deff671 21. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectAlgorithms.cpp:17: DB::MergeTreeInOrderSelectAlgorithm::getNewTask(DB::IMergeTreeReadPool&, DB::MergeTreeReadTask*) @ 0x000000002dea3919 22. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:0: DB::MergeTreeSelectProcessor::read() @ 0x000000002c8241d2 23. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000002de6d77a 24. ./build_docker/./src/Processors/ISource.cpp:0: DB::ISource::work() @ 0x000000002d3290a1 25. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 26. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 27. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000002d34877c 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000002d34827b 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*) @ 0x000000002d36bcf7 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 2025.09.09 15:03:50.375333 [ 3189 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:03:50.398300 [ 3192 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:03:51.051551 [ 3604 ] {a70935dd-9ffc-4589-93c7-d8f6af013e2f} executeQuery: Code: 191. DB::Exception: Limit for JOIN exceeded, max rows: 1.00 thousand, current rows: 66.57 thousand: While executing FillingRightJoinSide. (SET_SIZE_LIMIT_EXCEEDED) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:36822) (comment: 00074_full_join.sql) (in query: SELECT CounterID, hits, visits FROM ( SELECT (CounterID % 100000) AS CounterID, count() AS hits FROM test.hits GROUP BY CounterID ) ANY FULL OUTER JOIN ( SELECT (CounterID % 100000) AS CounterID, sum(Sign) AS visits FROM test.visits GROUP BY CounterID HAVING visits > 0 ) USING CounterID WHERE hits = 0 OR visits = 0 ORDER BY hits + visits * 10 DESC, CounterID ASC LIMIT 20;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, String&&, String&&) @ 0x00000000278b34e0 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:24: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b3073 5. ./build_docker/./src/Interpreters/HashJoin/HashJoin.cpp:0: DB::HashJoin::addBlockToJoin(DB::Block const&, bool) @ 0x0000000029d633de 6. ./build_docker/./src/Processors/Transforms/JoiningTransform.cpp:307: DB::FillingRightJoinSideTransform::work() @ 0x000000002d9dbab1 7. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:381: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000002d34bd35 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7eaf0 11. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001af8a79f 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 14. asan_thread_start(void*) @ 0x000000000aa43059 15. ? @ 0x00007f35aab92ac3 16. ? @ 0x00007f35aac24850 2025.09.09 15:03:51.063137 [ 3604 ] {a70935dd-9ffc-4589-93c7-d8f6af013e2f} TCPHandler: Code: 191. DB::Exception: Limit for JOIN exceeded, max rows: 1.00 thousand, current rows: 66.57 thousand: While executing FillingRightJoinSide. (SET_SIZE_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, String&&, String&&) @ 0x00000000278b34e0 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:24: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b3073 5. ./build_docker/./src/Interpreters/HashJoin/HashJoin.cpp:0: DB::HashJoin::addBlockToJoin(DB::Block const&, bool) @ 0x0000000029d633de 6. ./build_docker/./src/Processors/Transforms/JoiningTransform.cpp:307: DB::FillingRightJoinSideTransform::work() @ 0x000000002d9dbab1 7. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:381: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000002d34bd35 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7eaf0 11. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001af8a79f 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 14. asan_thread_start(void*) @ 0x000000000aa43059 15. ? @ 0x00007f35aab92ac3 16. ? @ 0x00007f35aac24850 2025.09.09 15:03:51.378467 [ 3219 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:03:51.401522 [ 3220 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:03:51.567698 [ 4025 ] {c966a1fa-bdaa-4f50-9173-94ce642762ed} executeQuery: Code: 48. DB::Exception: Storage Memory (table test_15.t0 (921ed07d-767e-4db2-b4ab-69d6bd0c8974)) does not support transactions: While processing SELECT 1 FROM (SELECT 1) AS tx INNER JOIN t0 ON true. (NOT_IMPLEMENTED) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:36836) (comment: 03282_memory_transaction_crash.sql) (in query: EXPLAIN SYNTAX SELECT 1 FROM (SELECT 1) tx JOIN t0 ON 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa91e9a 4. ./build_docker/./src/Interpreters/IInterpreter.cpp:43: DB::IInterpreter::checkStorageSupportsTransactionsIfNeeded(std::shared_ptr const&, std::shared_ptr, bool) @ 0x0000000029189ebc 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: 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) @ 0x0000000029379f60 6. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:382: 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) @ 0x000000002937744f 7. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:204: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000029376cf0 8. ./contrib/llvm-project/libcxx/include/vector:432: DB::InDepthNodeVisitor>::doVisit(std::shared_ptr&) @ 0x000000002920ca61 9. ./src/Interpreters/InDepthNodeVisitor.h:64: void DB::InDepthNodeVisitor>::visitChildren(std::shared_ptr&) @ 0x000000002920d0b6 10. ./src/Interpreters/InDepthNodeVisitor.h:0: void DB::InDepthNodeVisitor>::visitChildren(std::shared_ptr&) @ 0x000000002920d0c1 11. ./src/Interpreters/InDepthNodeVisitor.h:0: void DB::InDepthNodeVisitor>::visitChildren(std::shared_ptr&) @ 0x000000002920d0c1 12. ./src/Interpreters/InDepthNodeVisitor.h:0: DB::InterpreterExplainQuery::executeImpl() @ 0x00000000292000be 13. ./build_docker/./src/Interpreters/InterpreterExplainQuery.cpp:0: DB::InterpreterExplainQuery::execute() @ 0x00000000291fbabf 14. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b382fc 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 17. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 21. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 22. asan_thread_start(void*) @ 0x000000000aa43059 23. ? @ 0x00007f35aab92ac3 24. ? @ 0x00007f35aac24850 2025.09.09 15:03:51.575068 [ 4025 ] {c966a1fa-bdaa-4f50-9173-94ce642762ed} TCPHandler: Code: 48. DB::Exception: Storage Memory (table test_15.t0 (921ed07d-767e-4db2-b4ab-69d6bd0c8974)) does not support transactions: While processing SELECT 1 FROM (SELECT 1) AS tx INNER JOIN t0 ON true. (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa91e9a 4. ./build_docker/./src/Interpreters/IInterpreter.cpp:43: DB::IInterpreter::checkStorageSupportsTransactionsIfNeeded(std::shared_ptr const&, std::shared_ptr, bool) @ 0x0000000029189ebc 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: 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) @ 0x0000000029379f60 6. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:382: 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) @ 0x000000002937744f 7. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:204: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000029376cf0 8. ./contrib/llvm-project/libcxx/include/vector:432: DB::InDepthNodeVisitor>::doVisit(std::shared_ptr&) @ 0x000000002920ca61 9. ./src/Interpreters/InDepthNodeVisitor.h:64: void DB::InDepthNodeVisitor>::visitChildren(std::shared_ptr&) @ 0x000000002920d0b6 10. ./src/Interpreters/InDepthNodeVisitor.h:0: void DB::InDepthNodeVisitor>::visitChildren(std::shared_ptr&) @ 0x000000002920d0c1 11. ./src/Interpreters/InDepthNodeVisitor.h:0: void DB::InDepthNodeVisitor>::visitChildren(std::shared_ptr&) @ 0x000000002920d0c1 12. ./src/Interpreters/InDepthNodeVisitor.h:0: DB::InterpreterExplainQuery::executeImpl() @ 0x00000000292000be 13. ./build_docker/./src/Interpreters/InterpreterExplainQuery.cpp:0: DB::InterpreterExplainQuery::execute() @ 0x00000000291fbabf 14. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b382fc 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 17. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 21. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 22. asan_thread_start(void*) @ 0x000000000aa43059 23. ? @ 0x00007f35aab92ac3 24. ? @ 0x00007f35aac24850 2025.09.09 15:03:52.380647 [ 3238 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:03:52.501460 [ 3240 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:03:53.383777 [ 2758 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:03:53.499241 [ 17365 ] {0ed87fc4-af61-4840-9d2a-b7a5fa282cf1} executeQuery: Code: 57. DB::Exception: Table test_15.t2 already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:36874) (comment: 00830_join_overwrite.sql) (in query: CREATE TABLE t2 (k UInt32, v UInt32) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa91e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1558: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291bc5ff 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291ac835 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000291c3415 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b382fc 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 15. asan_thread_start(void*) @ 0x000000000aa43059 16. ? @ 0x00007f35aab92ac3 17. ? @ 0x00007f35aac24850 2025.09.09 15:03:53.501665 [ 17365 ] {0ed87fc4-af61-4840-9d2a-b7a5fa282cf1} TCPHandler: Code: 57. DB::Exception: Table test_15.t2 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa91e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1558: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291bc5ff 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291ac835 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000291c3415 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b382fc 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 15. asan_thread_start(void*) @ 0x000000000aa43059 16. ? @ 0x00007f35aab92ac3 17. ? @ 0x00007f35aac24850 2025.09.09 15:03:53.515953 [ 2761 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:03:54.386571 [ 2774 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:03:54.518607 [ 2781 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:03:55.389457 [ 2799 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:03:55.521530 [ 2812 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:03:56.391775 [ 2804 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:03:56.525330 [ 2824 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:03:57.393689 [ 2842 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:03:57.531175 [ 2845 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:03:58.031172 [ 4025 ] {66d38e0a-83e8-4712-8037-38707913995d} 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.10505.altinitytest (altinity build)) (from [::1]:36958) (comment: 02354_read_in_order_prewhere.sql) (in query: CREATE TABLE order (`ID` Int64, `Type` Int64, `Num` UInt64, `t` DateTime) ENGINE = MergeTree PARTITION BY toYYYYMMDD(t) ORDER BY (ID, Type, Num) SETTINGS index_granularity = 50347, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 0., replace_long_file_name_to_hash = true, max_file_name_length = 128, min_bytes_for_full_part_storage = 0, compact_parts_max_bytes_to_buffer = 265838810, compact_parts_max_granules_to_buffer = 64, compact_parts_merge_max_bytes_to_prefetch_part = 13900762, merge_max_block_size = 1507, old_parts_lifetime = 10., prefer_fetch_merged_part_size_threshold = 10737418240, vertical_merge_algorithm_min_rows_to_activate = 1000000, vertical_merge_algorithm_min_columns_to_activate = 100, min_merge_bytes_to_use_direct_io = 1, index_granularity_bytes = 14066687, concurrent_part_removal_threshold = 100, allow_vertical_merges_from_compact_to_wide_parts = true, cache_populated_by_fetch = false, marks_compress_block_size = 32020, primary_key_compress_block_size = 24133), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af819ed 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80746 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000263a174e 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002c45d4f6 8. ./contrib/llvm-project/libcxx/include/optional:260: DB::StorageMergeTree::StorageMergeTree(DB::StorageID const&, String const&, DB::StorageInMemoryMetadata const&, DB::LoadingStrictnessLevel, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>) @ 0x000000002cbacf28 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:1460: std::shared_ptr std::allocate_shared[abi:v15007], DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, void>(std::allocator const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&) @ 0x000000002cbabafa 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:962: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000002cba21b8 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 @ 0x000000002b77bf53 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291b9254 13. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291ac835 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000291c3415 15. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b382fc 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 18. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 22. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:03:58.040181 [ 4025 ] {66d38e0a-83e8-4712-8037-38707913995d} 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af819ed 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80746 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000263a174e 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002c45d4f6 8. ./contrib/llvm-project/libcxx/include/optional:260: DB::StorageMergeTree::StorageMergeTree(DB::StorageID const&, String const&, DB::StorageInMemoryMetadata const&, DB::LoadingStrictnessLevel, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>) @ 0x000000002cbacf28 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:1460: std::shared_ptr std::allocate_shared[abi:v15007], DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, void>(std::allocator const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&) @ 0x000000002cbabafa 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:962: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000002cba21b8 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 @ 0x000000002b77bf53 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291b9254 13. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291ac835 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000291c3415 15. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b382fc 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 18. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 22. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:03:58.395875 [ 2862 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:03:58.533054 [ 2846 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:03:59.398090 [ 2871 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:03:59.535344 [ 2900 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:04:00.400112 [ 2917 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:04:00.537492 [ 2918 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:04:01.402241 [ 2940 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:04:01.539416 [ 2937 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:04:02.404692 [ 2950 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:04:02.542633 [ 2968 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:04:02.826420 [ 4025 ] {dc9908d6-d2a8-414a-8014-4d07641f4769} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=13, jobs=1): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:38390) (comment: 00594_alias_in_distributed.sql) (in query: SELECT field3 FROM alias10 WHERE EventDate='2000-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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af80b71 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80746 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002c765aab 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:1197: ? @ 0x000000002c7602b8 8. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x000000002c75fc2b 9. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:0: DB::MergeTreeReaderCompact::MergeTreeReaderCompact(std::shared_ptr, DB::NamesAndTypesList, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*, DB::MarkCache*, DB::MarkRanges, DB::MergeTreeReaderSettings, std::map, std::allocator>>, std::function const&, int) @ 0x000000002c7aee03 10. ./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.h:16: DB::MergeTreeReaderCompactSingleBuffer::MergeTreeReaderCompactSingleBuffer&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int&&) @ 0x000000002c5d6d21 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::MergeTreeDataPartCompact::getReader(DB::NamesAndTypesList const&, std::shared_ptr const&, DB::MarkRanges const&, std::unordered_map, std::equal_to, std::allocator>> const&, DB::UncompressedCache*, DB::MarkCache*, std::shared_ptr const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) const @ 0x000000002c5d1037 12. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:44: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x000000002c82acda 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:295: DB::MergeTreeReadPoolBase::createTask(std::shared_ptr, DB::MarkRanges, DB::MergeTreeReadTask*) const @ 0x000000002de9c234 14. ./build_docker/./src/Storages/MergeTree/MergeTreeReadPoolInOrder.cpp:72: DB::MergeTreeReadPoolInOrder::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x000000002deff671 15. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectAlgorithms.cpp:17: DB::MergeTreeInOrderSelectAlgorithm::getNewTask(DB::IMergeTreeReadPool&, DB::MergeTreeReadTask*) @ 0x000000002dea3919 16. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:0: DB::MergeTreeSelectProcessor::read() @ 0x000000002c8241d2 17. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000002de6d77a 18. ./build_docker/./src/Processors/ISource.cpp:0: DB::ISource::work() @ 0x000000002d3290a1 19. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 20. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 21. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000002d34877c 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000002d34827b 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*) @ 0x000000002d36bcf7 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 26. asan_thread_start(void*) @ 0x000000000aa43059 27. ? @ 0x00007f35aab92ac3 28. ? @ 0x00007f35aac24850 2025.09.09 15:04:02.829175 [ 4025 ] {dc9908d6-d2a8-414a-8014-4d07641f4769} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=13, jobs=1): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af80b71 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80746 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002c765aab 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:1197: ? @ 0x000000002c7602b8 8. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x000000002c75fc2b 9. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:0: DB::MergeTreeReaderCompact::MergeTreeReaderCompact(std::shared_ptr, DB::NamesAndTypesList, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*, DB::MarkCache*, DB::MarkRanges, DB::MergeTreeReaderSettings, std::map, std::allocator>>, std::function const&, int) @ 0x000000002c7aee03 10. ./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.h:16: DB::MergeTreeReaderCompactSingleBuffer::MergeTreeReaderCompactSingleBuffer&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int&&) @ 0x000000002c5d6d21 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::MergeTreeDataPartCompact::getReader(DB::NamesAndTypesList const&, std::shared_ptr const&, DB::MarkRanges const&, std::unordered_map, std::equal_to, std::allocator>> const&, DB::UncompressedCache*, DB::MarkCache*, std::shared_ptr const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) const @ 0x000000002c5d1037 12. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:44: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x000000002c82acda 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:295: DB::MergeTreeReadPoolBase::createTask(std::shared_ptr, DB::MarkRanges, DB::MergeTreeReadTask*) const @ 0x000000002de9c234 14. ./build_docker/./src/Storages/MergeTree/MergeTreeReadPoolInOrder.cpp:72: DB::MergeTreeReadPoolInOrder::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x000000002deff671 15. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectAlgorithms.cpp:17: DB::MergeTreeInOrderSelectAlgorithm::getNewTask(DB::IMergeTreeReadPool&, DB::MergeTreeReadTask*) @ 0x000000002dea3919 16. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:0: DB::MergeTreeSelectProcessor::read() @ 0x000000002c8241d2 17. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000002de6d77a 18. ./build_docker/./src/Processors/ISource.cpp:0: DB::ISource::work() @ 0x000000002d3290a1 19. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 20. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 21. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000002d34877c 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000002d34827b 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*) @ 0x000000002d36bcf7 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 26. asan_thread_start(void*) @ 0x000000000aa43059 27. ? @ 0x00007f35aab92ac3 28. ? @ 0x00007f35aac24850 2025.09.09 15:04:03.407971 [ 2989 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:04:03.545732 [ 2971 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:04:04.302039 [ 18141 ] {680c8a79-a6fa-4a78-8589-30ebefb27804} executeQuery: Code: 57. DB::Exception: Table test_3.test already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:36930) (comment: 02721_url_cluster.sql) (in query: create table test (x UInt32, y UInt32, z UInt32) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa91e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1558: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291bc5ff 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291ac835 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000291c3415 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b382fc 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 15. asan_thread_start(void*) @ 0x000000000aa43059 16. ? @ 0x00007f35aab92ac3 17. ? @ 0x00007f35aac24850 2025.09.09 15:04:04.310784 [ 18141 ] {680c8a79-a6fa-4a78-8589-30ebefb27804} TCPHandler: Code: 57. DB::Exception: Table test_3.test already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa91e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1558: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291bc5ff 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291ac835 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000291c3415 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b382fc 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 15. asan_thread_start(void*) @ 0x000000000aa43059 16. ? @ 0x00007f35aab92ac3 17. ? @ 0x00007f35aac24850 2025.09.09 15:04:04.410847 [ 3006 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:04:04.548795 [ 3001 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:04:05.414139 [ 3034 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:04:05.551848 [ 3028 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:04:05.825700 [ 13328 ] {} DynamicQueryHandler: Code: 452. DB::Exception: Setting max_execution_time shouldn't be greater than 60. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x0000000026f841fa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:368: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f81de0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/find_if.h:25: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f808a4 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000002d065739 10. ./build_docker/./src/Server/HTTPHandler.cpp:705: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000002d06d139 11. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000002d1cc337 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 15. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 16. asan_thread_start(void*) @ 0x000000000aa43059 17. ? @ 0x00007f35aab92ac3 18. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:04:06.417619 [ 3059 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:04:06.555114 [ 3057 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:04:06.617641 [ 3485 ] {cb03bf63-5f74-45ba-9442-5263f74ade44} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=0, jobs=0). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from 0.0.0.0:0) (comment: 03068_analyzer_distributed_join.sql) (in query: /* ddl_entry=query-0000000001 */ CREATE TABLE test_3.ORDERS_shard UUID 'cb4aaae6-e028-417c-8ff8-4eb188f08c80' (`O_ORDERKEY` UInt64, `O_ORDERPRIORITY` UInt32) ENGINE = MergeTree ORDER BY O_ORDERKEY SETTINGS index_granularity = 49776, min_bytes_for_wide_part = 112260155, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = false, max_file_name_length = 14, min_bytes_for_full_part_storage = 332667894, compact_parts_max_bytes_to_buffer = 217448622, compact_parts_max_granules_to_buffer = 135, compact_parts_merge_max_bytes_to_prefetch_part = 23827165, merge_max_block_size = 3278, old_parts_lifetime = 275., prefer_fetch_merged_part_size_threshold = 7805691848, vertical_merge_algorithm_min_rows_to_activate = 1, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 2555293303, index_granularity_bytes = 28770769, concurrent_part_removal_threshold = 0, allow_vertical_merges_from_compact_to_wide_parts = false, cache_populated_by_fetch = true, marks_compress_block_size = 40282, primary_key_compress_block_size = 70107), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af80b71 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80746 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000263a174e 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002c45d4f6 8. ./contrib/llvm-project/libcxx/include/optional:260: DB::StorageMergeTree::StorageMergeTree(DB::StorageID const&, String const&, DB::StorageInMemoryMetadata const&, DB::LoadingStrictnessLevel, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>) @ 0x000000002cbacf28 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:1460: std::shared_ptr std::allocate_shared[abi:v15007], DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, void>(std::allocator const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&) @ 0x000000002cbabafa 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:962: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000002cba21b8 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 @ 0x000000002b77bf53 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291b9254 13. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291ac835 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000291c3415 15. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b382fc 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1529: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000029b3ed3f 17. ./build_docker/./src/Interpreters/DDLWorker.cpp:498: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000028686d70 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000028682a53 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::DDLWorker::scheduleTasks(bool) @ 0x000000002867e346 20. ./build_docker/./src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::runMainThread() @ 0x0000000028672c48 21. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286a04bf 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 24. asan_thread_start(void*) @ 0x000000000aa43059 25. ? @ 0x00007f35aab92ac3 26. ? @ 0x00007f35aac24850 2025.09.09 15:04:06.624810 [ 3485 ] {cb03bf63-5f74-45ba-9442-5263f74ade44} DDLWorker: Query /* ddl_entry=query-0000000001 */ CREATE TABLE test_3.ORDERS_shard UUID 'cb4aaae6-e028-417c-8ff8-4eb188f08c80' (`O_ORDERKEY` UInt64, `O_ORDERPRIORITY` UInt32) ENGINE = MergeTree ORDER BY O_ORDERKEY SETTINGS index_granularity = 49776, min_bytes_for_wide_part = 112260155, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = false, max_file_name_length = 14, min_bytes_for_full_part_storage = 332667894, compact_parts_max_bytes_to_buffer = 217448622, compact_parts_max_granules_to_buffer = 135, compact_parts_merge_max_bytes_to_prefetch_part = 23827165, merge_max_block_size = 3278, old_parts_lifetime = 275., prefer_fetch_merged_part_size_threshold = 7805691848, vertical_merge_algorithm_min_rows_to_activate = 1, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 2555293303, index_granularity_bytes = 28770769, concurrent_part_removal_threshold = 0, allow_vertical_merges_from_compact_to_wide_parts = false, cache_populated_by_fetch = true, marks_compress_block_size = 40282, primary_key_compress_block_size = 70107 wasn't finished successfully: 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af80b71 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80746 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000263a174e 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002c45d4f6 8. ./contrib/llvm-project/libcxx/include/optional:260: DB::StorageMergeTree::StorageMergeTree(DB::StorageID const&, String const&, DB::StorageInMemoryMetadata const&, DB::LoadingStrictnessLevel, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>) @ 0x000000002cbacf28 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:1460: std::shared_ptr std::allocate_shared[abi:v15007], DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, void>(std::allocator const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&) @ 0x000000002cbabafa 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:962: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000002cba21b8 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 @ 0x000000002b77bf53 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291b9254 13. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291ac835 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000291c3415 15. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b382fc 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1529: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000029b3ed3f 17. ./build_docker/./src/Interpreters/DDLWorker.cpp:498: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000028686d70 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000028682a53 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::DDLWorker::scheduleTasks(bool) @ 0x000000002867e346 20. ./build_docker/./src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::runMainThread() @ 0x0000000028672c48 21. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286a04bf 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 24. asan_thread_start(void*) @ 0x000000000aa43059 25. ? @ 0x00007f35aab92ac3 26. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:04:06.929975 [ 17365 ] {864f4d3c-6eb4-4ab3-b3d2-4cbbfeb67403} executeQuery: Code: 439. DB::Exception: There was an error on [localhost:9000]: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=0, jobs=0). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:38420) (comment: 03068_analyzer_distributed_join.sql) (in query: CREATE TABLE ORDERS_shard ON CLUSTER test_shard_localhost (`O_ORDERKEY` UInt64, `O_ORDERPRIORITY` UInt32) ENGINE = MergeTree ORDER BY O_ORDERKEY SETTINGS index_granularity = 49776, min_bytes_for_wide_part = 112260155, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = false, max_file_name_length = 14, min_bytes_for_full_part_storage = 332667894, compact_parts_max_bytes_to_buffer = 217448622, compact_parts_max_granules_to_buffer = 135, compact_parts_merge_max_bytes_to_prefetch_part = 23827165, merge_max_block_size = 3278, old_parts_lifetime = 275., prefer_fetch_merged_part_size_threshold = 7805691848, vertical_merge_algorithm_min_rows_to_activate = 1, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 2555293303, index_granularity_bytes = 28770769, concurrent_part_removal_threshold = 0, allow_vertical_merges_from_compact_to_wide_parts = false, cache_populated_by_fetch = true, marks_compress_block_size = 40282, primary_key_compress_block_size = 70107), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/Exception.h:0: DB::DDLQueryStatusSource::generate() @ 0x0000000029b0fd93 4. ./src/Processors/Chunk.h:110: DB::ISource::tryGenerate() @ 0x000000002d329c18 5. ./build_docker/./src/Processors/ISource.cpp:0: DB::ISource::work() @ 0x000000002d3290a1 6. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000002d34877c 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000002d34827b 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002d36bcf7 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 13. asan_thread_start(void*) @ 0x000000000aa43059 14. ? @ 0x00007f35aab92ac3 15. ? @ 0x00007f35aac24850 2025.09.09 15:04:06.944503 [ 17365 ] {864f4d3c-6eb4-4ab3-b3d2-4cbbfeb67403} TCPHandler: Code: 439. DB::Exception: There was an error on [localhost:9000]: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=0, jobs=0). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/Exception.h:0: DB::DDLQueryStatusSource::generate() @ 0x0000000029b0fd93 4. ./src/Processors/Chunk.h:110: DB::ISource::tryGenerate() @ 0x000000002d329c18 5. ./build_docker/./src/Processors/ISource.cpp:0: DB::ISource::work() @ 0x000000002d3290a1 6. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000002d34877c 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000002d34827b 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002d36bcf7 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 13. asan_thread_start(void*) @ 0x000000000aa43059 14. ? @ 0x00007f35aab92ac3 15. ? @ 0x00007f35aac24850 2025.09.09 15:04:07.327636 [ 4025 ] {076b5568-29fb-49d2-bf8a-b36433a2ae37} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=773, jobs=735). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:38410) (comment: 02366_kql_func_datetime.sql) (in query: print startofday(datetime(2017-01-01 10:10:17), 1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af872f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af7b2d1 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af7c3f3 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d36920d 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000002d369e5f 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processOrdinaryQuery() @ 0x000000002d18af7b 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d17644a 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 15. asan_thread_start(void*) @ 0x000000000aa43059 16. ? @ 0x00007f35aab92ac3 17. ? @ 0x00007f35aac24850 2025.09.09 15:04:07.331929 [ 4025 ] {076b5568-29fb-49d2-bf8a-b36433a2ae37} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=773, 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af872f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af7b2d1 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af7c3f3 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d36920d 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000002d369e5f 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processOrdinaryQuery() @ 0x000000002d18af7b 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d17644a 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 15. asan_thread_start(void*) @ 0x000000000aa43059 16. ? @ 0x00007f35aab92ac3 17. ? @ 0x00007f35aac24850 2025.09.09 15:04:07.414668 [ 13328 ] {} DynamicQueryHandler: Code: 452. DB::Exception: Setting max_execution_time shouldn't be greater than 60. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x0000000026f841fa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:368: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f81de0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/find_if.h:25: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f808a4 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000002d065739 10. ./build_docker/./src/Server/HTTPHandler.cpp:705: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000002d06d139 11. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000002d1cc337 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 15. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 16. asan_thread_start(void*) @ 0x000000000aa43059 17. ? @ 0x00007f35aab92ac3 18. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:04:07.420864 [ 3090 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:04:07.558221 [ 3093 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:04:08.423671 [ 3112 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:04:08.561960 [ 3117 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:04:09.427610 [ 3138 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:04:09.564976 [ 3142 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:04:10.430840 [ 3173 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:04:10.567209 [ 3181 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:04:11.433064 [ 3183 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:04:11.569165 [ 3198 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:04:12.435414 [ 3220 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:04:12.571919 [ 3210 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:04:13.437575 [ 3241 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:04:13.574616 [ 2750 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:04:14.439835 [ 3236 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:04:14.491144 [ 17365 ] {3b082717-15ff-405e-9914-922dbfb0657f} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=773, jobs=735). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:41568) (comment: 01554_bloom_filter_index_big_integer_uuid.sql) (in query: SELECT x FROM 01154_test WHERE x = 1;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af872f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af7b2d1 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af7c3f3 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d36920d 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000002d369e5f 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processOrdinaryQuery() @ 0x000000002d18af7b 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d17644a 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 15. asan_thread_start(void*) @ 0x000000000aa43059 16. ? @ 0x00007f35aab92ac3 17. ? @ 0x00007f35aac24850 2025.09.09 15:04:14.493273 [ 17365 ] {3b082717-15ff-405e-9914-922dbfb0657f} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=773, 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af872f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af7b2d1 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af7c3f3 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d36920d 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000002d369e5f 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processOrdinaryQuery() @ 0x000000002d18af7b 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d17644a 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 15. asan_thread_start(void*) @ 0x000000000aa43059 16. ? @ 0x00007f35aab92ac3 17. ? @ 0x00007f35aac24850 2025.09.09 15:04:14.576904 [ 2755 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:04:15.442417 [ 2780 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:04:15.490770 [ 17365 ] {e8c6fed7-9a26-41b4-b114-a3db126b70d5} executeQuery: Code: 43. DB::Exception: Illegal type String expression, must be numeric type. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:41580) (comment: 01702_system_numbers_scientific_notation.sql) (in query: select * from numbers_mt('100') format Null;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000aad4b34 4. ./build_docker/./src/TableFunctions/TableFunctionNumbers.cpp:108: DB::(anonymous namespace)::TableFunctionNumbers::evaluateArgument(std::shared_ptr, std::shared_ptr&) const @ 0x0000000025fb7536 5. ./build_docker/./src/TableFunctions/TableFunctionNumbers.cpp:80: DB::(anonymous namespace)::TableFunctionNumbers::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x0000000025fb6640 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 @ 0x00000000265c241e 7. ./build_docker/./src/Interpreters/Context.cpp:2234: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000285361d2 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4819: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000002837024e 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000283ba404 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002835ad09 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000028359104 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000028357f0d 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002921bdcc 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&) @ 0x000000002941f313 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&) @ 0x0000000029419aef 16. ./contrib/llvm-project/libcxx/include/vector:432: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000029421f5d 17. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000029344c1b 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*) @ 0x0000000029b3703b 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 21. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 25. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 26. asan_thread_start(void*) @ 0x000000000aa43059 27. ? @ 0x00007f35aab92ac3 28. ? @ 0x00007f35aac24850 2025.09.09 15:04:15.494088 [ 17365 ] {e8c6fed7-9a26-41b4-b114-a3db126b70d5} TCPHandler: Code: 43. DB::Exception: Illegal type String expression, must be numeric type. (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000aad4b34 4. ./build_docker/./src/TableFunctions/TableFunctionNumbers.cpp:108: DB::(anonymous namespace)::TableFunctionNumbers::evaluateArgument(std::shared_ptr, std::shared_ptr&) const @ 0x0000000025fb7536 5. ./build_docker/./src/TableFunctions/TableFunctionNumbers.cpp:80: DB::(anonymous namespace)::TableFunctionNumbers::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x0000000025fb6640 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 @ 0x00000000265c241e 7. ./build_docker/./src/Interpreters/Context.cpp:2234: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000285361d2 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4819: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000002837024e 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000283ba404 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002835ad09 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000028359104 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000028357f0d 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002921bdcc 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&) @ 0x000000002941f313 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&) @ 0x0000000029419aef 16. ./contrib/llvm-project/libcxx/include/vector:432: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000029421f5d 17. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000029344c1b 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*) @ 0x0000000029b3703b 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 21. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 25. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 26. asan_thread_start(void*) @ 0x000000000aa43059 27. ? @ 0x00007f35aab92ac3 28. ? @ 0x00007f35aac24850 2025.09.09 15:04:15.579898 [ 2781 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:04:15.892574 [ 17365 ] {6f39ff4e-7039-4409-8df5-2f04532742ba} executeQuery: Code: 43. DB::Exception: The value inf is not representable as UInt64. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:41580) (comment: 01702_system_numbers_scientific_notation.sql) (in query: select * from numbers_mt(inf) format Null;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000aad4b34 4. ./build_docker/./src/TableFunctions/TableFunctionNumbers.cpp:112: DB::(anonymous namespace)::TableFunctionNumbers::evaluateArgument(std::shared_ptr, std::shared_ptr&) const @ 0x0000000025fb74a6 5. ./build_docker/./src/TableFunctions/TableFunctionNumbers.cpp:80: DB::(anonymous namespace)::TableFunctionNumbers::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x0000000025fb6640 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 @ 0x00000000265c241e 7. ./build_docker/./src/Interpreters/Context.cpp:2234: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000285361d2 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4819: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000002837024e 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000283ba404 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002835ad09 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000028359104 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000028357f0d 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002921bdcc 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&) @ 0x000000002941f313 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&) @ 0x0000000029419aef 16. ./contrib/llvm-project/libcxx/include/vector:432: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000029421f5d 17. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000029344c1b 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*) @ 0x0000000029b3703b 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 21. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 25. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 26. asan_thread_start(void*) @ 0x000000000aa43059 27. ? @ 0x00007f35aab92ac3 28. ? @ 0x00007f35aac24850 2025.09.09 15:04:15.897277 [ 17365 ] {6f39ff4e-7039-4409-8df5-2f04532742ba} TCPHandler: Code: 43. DB::Exception: The value inf is not representable as UInt64. (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000aad4b34 4. ./build_docker/./src/TableFunctions/TableFunctionNumbers.cpp:112: DB::(anonymous namespace)::TableFunctionNumbers::evaluateArgument(std::shared_ptr, std::shared_ptr&) const @ 0x0000000025fb74a6 5. ./build_docker/./src/TableFunctions/TableFunctionNumbers.cpp:80: DB::(anonymous namespace)::TableFunctionNumbers::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x0000000025fb6640 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 @ 0x00000000265c241e 7. ./build_docker/./src/Interpreters/Context.cpp:2234: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000285361d2 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4819: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000002837024e 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000283ba404 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002835ad09 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000028359104 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000028357f0d 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002921bdcc 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&) @ 0x000000002941f313 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&) @ 0x0000000029419aef 16. ./contrib/llvm-project/libcxx/include/vector:432: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000029421f5d 17. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000029344c1b 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*) @ 0x0000000029b3703b 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 21. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 25. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 26. asan_thread_start(void*) @ 0x000000000aa43059 27. ? @ 0x00007f35aab92ac3 28. ? @ 0x00007f35aac24850 2025.09.09 15:04:15.929381 [ 17365 ] {72b72c8c-aa99-44bc-a32b-b44818bb5b29} executeQuery: Code: 43. DB::Exception: The value nan is not representable as UInt64. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:41580) (comment: 01702_system_numbers_scientific_notation.sql) (in query: select * from numbers_mt(nan) format Null;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000aad4b34 4. ./build_docker/./src/TableFunctions/TableFunctionNumbers.cpp:112: DB::(anonymous namespace)::TableFunctionNumbers::evaluateArgument(std::shared_ptr, std::shared_ptr&) const @ 0x0000000025fb74a6 5. ./build_docker/./src/TableFunctions/TableFunctionNumbers.cpp:80: DB::(anonymous namespace)::TableFunctionNumbers::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x0000000025fb6640 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 @ 0x00000000265c241e 7. ./build_docker/./src/Interpreters/Context.cpp:2234: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000285361d2 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4819: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000002837024e 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000283ba404 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002835ad09 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000028359104 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000028357f0d 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002921bdcc 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&) @ 0x000000002941f313 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&) @ 0x0000000029419aef 16. ./contrib/llvm-project/libcxx/include/vector:432: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000029421f5d 17. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000029344c1b 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*) @ 0x0000000029b3703b 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 21. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 25. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 26. asan_thread_start(void*) @ 0x000000000aa43059 27. ? @ 0x00007f35aab92ac3 28. ? @ 0x00007f35aac24850 2025.09.09 15:04:15.933308 [ 17365 ] {72b72c8c-aa99-44bc-a32b-b44818bb5b29} TCPHandler: Code: 43. DB::Exception: The value nan is not representable as UInt64. (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000aad4b34 4. ./build_docker/./src/TableFunctions/TableFunctionNumbers.cpp:112: DB::(anonymous namespace)::TableFunctionNumbers::evaluateArgument(std::shared_ptr, std::shared_ptr&) const @ 0x0000000025fb74a6 5. ./build_docker/./src/TableFunctions/TableFunctionNumbers.cpp:80: DB::(anonymous namespace)::TableFunctionNumbers::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x0000000025fb6640 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 @ 0x00000000265c241e 7. ./build_docker/./src/Interpreters/Context.cpp:2234: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000285361d2 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4819: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000002837024e 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000283ba404 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002835ad09 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000028359104 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000028357f0d 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002921bdcc 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&) @ 0x000000002941f313 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&) @ 0x0000000029419aef 16. ./contrib/llvm-project/libcxx/include/vector:432: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000029421f5d 17. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000029344c1b 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*) @ 0x0000000029b3703b 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 21. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 25. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 26. asan_thread_start(void*) @ 0x000000000aa43059 27. ? @ 0x00007f35aab92ac3 28. ? @ 0x00007f35aac24850 2025.09.09 15:04:16.445993 [ 2809 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:04:16.583038 [ 2816 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:04:17.449357 [ 2838 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:04:17.588081 [ 2840 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:04:18.452363 [ 2872 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:04:18.591900 [ 2863 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:04:18.994931 [ 3612 ] {e27c9ca9-c395-4c04-897e-b4fa31200a96} executeQuery: Code: 48. DB::Exception: Can't execute any of specified join algorithms for this strictness/kind and right storage type: While processing SELECT a, b, t2_00826.a, t2_00826.b FROM t1_00826 CROSS JOIN t2_00826 WHERE a = b. (NOT_IMPLEMENTED) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:41566) (comment: 00826_cross_to_inner_join.sql) (in query: EXPLAIN SYNTAX SELECT * FROM t1_00826 cross join t2_00826 where t1_00826.a = t1_00826.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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aac868e 4. ./build_docker/./src/Interpreters/ExpressionAnalyzer.cpp:1046: DB::SelectQueryExpressionAnalyzer::makeJoin(DB::ASTTablesInSelectQueryElement const&, std::vector> const&, std::optional&) @ 0x0000000028739c38 5. ./build_docker/./src/Interpreters/ExpressionAnalyzer.cpp:948: DB::SelectQueryExpressionAnalyzer::appendJoin(DB::ExpressionActionsChain&, std::shared_ptr&) @ 0x0000000028735a90 6. ./build_docker/./src/Interpreters/ExpressionAnalyzer.cpp:0: DB::ExpressionAnalysisResult::ExpressionAnalysisResult(DB::SelectQueryExpressionAnalyzer&, std::shared_ptr const&, bool, bool, bool, std::shared_ptr const&, std::shared_ptr const&, DB::Block const&) @ 0x000000002874cc55 7. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:1073: DB::InterpreterSelectQuery::getSampleBlockImpl() @ 0x000000002939d21e 8. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:812: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, std::optional, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr)::$_0::operator()(bool) const @ 0x000000002938a949 9. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:0: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, std::optional, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002937db9e 10. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:382: 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) @ 0x000000002937744f 11. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:204: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000029376cf0 12. ./contrib/llvm-project/libcxx/include/vector:432: DB::InDepthNodeVisitor>::doVisit(std::shared_ptr&) @ 0x000000002920ca61 13. ./src/Interpreters/InDepthNodeVisitor.h:64: void DB::InDepthNodeVisitor>::visitChildren(std::shared_ptr&) @ 0x000000002920d0b6 14. ./src/Interpreters/InDepthNodeVisitor.h:0: void DB::InDepthNodeVisitor>::visitChildren(std::shared_ptr&) @ 0x000000002920d0c1 15. ./src/Interpreters/InDepthNodeVisitor.h:0: void DB::InDepthNodeVisitor>::visitChildren(std::shared_ptr&) @ 0x000000002920d0c1 16. ./src/Interpreters/InDepthNodeVisitor.h:0: DB::InterpreterExplainQuery::executeImpl() @ 0x00000000292000be 17. ./build_docker/./src/Interpreters/InterpreterExplainQuery.cpp:0: DB::InterpreterExplainQuery::execute() @ 0x00000000291fbabf 18. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b382fc 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 21. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 25. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 26. asan_thread_start(void*) @ 0x000000000aa43059 27. ? @ 0x00007f35aab92ac3 28. ? @ 0x00007f35aac24850 2025.09.09 15:04:19.000929 [ 3612 ] {e27c9ca9-c395-4c04-897e-b4fa31200a96} TCPHandler: Code: 48. DB::Exception: Can't execute any of specified join algorithms for this strictness/kind and right storage type: While processing SELECT a, b, t2_00826.a, t2_00826.b FROM t1_00826 CROSS JOIN t2_00826 WHERE a = b. (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aac868e 4. ./build_docker/./src/Interpreters/ExpressionAnalyzer.cpp:1046: DB::SelectQueryExpressionAnalyzer::makeJoin(DB::ASTTablesInSelectQueryElement const&, std::vector> const&, std::optional&) @ 0x0000000028739c38 5. ./build_docker/./src/Interpreters/ExpressionAnalyzer.cpp:948: DB::SelectQueryExpressionAnalyzer::appendJoin(DB::ExpressionActionsChain&, std::shared_ptr&) @ 0x0000000028735a90 6. ./build_docker/./src/Interpreters/ExpressionAnalyzer.cpp:0: DB::ExpressionAnalysisResult::ExpressionAnalysisResult(DB::SelectQueryExpressionAnalyzer&, std::shared_ptr const&, bool, bool, bool, std::shared_ptr const&, std::shared_ptr const&, DB::Block const&) @ 0x000000002874cc55 7. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:1073: DB::InterpreterSelectQuery::getSampleBlockImpl() @ 0x000000002939d21e 8. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:812: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, std::optional, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr)::$_0::operator()(bool) const @ 0x000000002938a949 9. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:0: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, std::optional, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002937db9e 10. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:382: 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) @ 0x000000002937744f 11. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:204: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000029376cf0 12. ./contrib/llvm-project/libcxx/include/vector:432: DB::InDepthNodeVisitor>::doVisit(std::shared_ptr&) @ 0x000000002920ca61 13. ./src/Interpreters/InDepthNodeVisitor.h:64: void DB::InDepthNodeVisitor>::visitChildren(std::shared_ptr&) @ 0x000000002920d0b6 14. ./src/Interpreters/InDepthNodeVisitor.h:0: void DB::InDepthNodeVisitor>::visitChildren(std::shared_ptr&) @ 0x000000002920d0c1 15. ./src/Interpreters/InDepthNodeVisitor.h:0: void DB::InDepthNodeVisitor>::visitChildren(std::shared_ptr&) @ 0x000000002920d0c1 16. ./src/Interpreters/InDepthNodeVisitor.h:0: DB::InterpreterExplainQuery::executeImpl() @ 0x00000000292000be 17. ./build_docker/./src/Interpreters/InterpreterExplainQuery.cpp:0: DB::InterpreterExplainQuery::execute() @ 0x00000000291fbabf 18. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b382fc 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 21. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 25. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 26. asan_thread_start(void*) @ 0x000000000aa43059 27. ? @ 0x00007f35aab92ac3 28. ? @ 0x00007f35aac24850 2025.09.09 15:04:19.455858 [ 2876 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:04:19.595003 [ 2882 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:04:20.326899 [ 17365 ] {f622822c-170b-41db-8233-af29e04e9fb9} executeQuery: Code: 36. DB::Exception: The value of 'number_of_free_entries_in_pool_to_execute_mutation' setting (100) (default values are defined in section of config.xml or the value can be specified per table in SETTINGS section of CREATE TABLE query) is greater than the value of 'background_pool_size'*'background_merges_mutations_concurrency_ratio' (32) (the value is defined in users.xml for default profile). This indicates incorrect configuration because mutations cannot work with these settings. (BAD_ARGUMENTS) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:39032) (comment: 01419_merge_tree_settings_sanity_check.sql) (in query: CREATE TABLE mytable_local (`created` DateTime, `eventday` Date, `user_id` UInt32) ENGINE = MergeTree PARTITION BY toYYYYMM(eventday) ORDER BY (eventday, user_id) SETTINGS number_of_free_entries_in_pool_to_execute_mutation = 100, index_granularity = 22919, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = false, max_file_name_length = 0, min_bytes_for_full_part_storage = 356152698, compact_parts_max_bytes_to_buffer = 38258153, compact_parts_max_granules_to_buffer = 123, compact_parts_merge_max_bytes_to_prefetch_part = 10490220, merge_max_block_size = 12241, old_parts_lifetime = 117., 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 = 6599255762, index_granularity_bytes = 29496560, concurrent_part_removal_threshold = 4, allow_vertical_merges_from_compact_to_wide_parts = false, cache_populated_by_fetch = true, marks_compress_block_size = 90374, primary_key_compress_block_size = 70024), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception const&, unsigned long&>(int, FormatStringHelperImpl const&>::type, std::type_identity::type>, DB::SettingFieldNumber const&, unsigned long&) @ 0x000000002c8b2c5a 4. ./build_docker/./src/Storages/MergeTree/MergeTreeSettings.cpp:0: DB::MergeTreeSettings::sanityCheck(unsigned long) const @ 0x000000002c84e186 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::MergeTreeData::MergeTreeData(DB::StorageID const&, DB::StorageInMemoryMetadata const&, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>, bool, DB::LoadingStrictnessLevel, std::function) @ 0x000000002c4327b2 6. ./build_docker/./src/Storages/StorageMergeTree.cpp:96: DB::StorageMergeTree::StorageMergeTree(DB::StorageID const&, String const&, DB::StorageInMemoryMetadata const&, DB::LoadingStrictnessLevel, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>) @ 0x000000002cbacb89 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:1460: std::shared_ptr std::allocate_shared[abi:v15007], DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, void>(std::allocator const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&) @ 0x000000002cbabafa 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:962: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000002cba21b8 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 @ 0x000000002b77bf53 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291b9254 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291ac835 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000291c3415 13. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b382fc 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 16. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 20. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 21. asan_thread_start(void*) @ 0x000000000aa43059 22. ? @ 0x00007f35aab92ac3 23. ? @ 0x00007f35aac24850 2025.09.09 15:04:20.330107 [ 17365 ] {f622822c-170b-41db-8233-af29e04e9fb9} TCPHandler: Code: 36. DB::Exception: The value of 'number_of_free_entries_in_pool_to_execute_mutation' setting (100) (default values are defined in section of config.xml or the value can be specified per table in SETTINGS section of CREATE TABLE query) is greater than the value of 'background_pool_size'*'background_merges_mutations_concurrency_ratio' (32) (the value is defined in users.xml for default profile). This indicates incorrect configuration because mutations cannot work with these settings. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception const&, unsigned long&>(int, FormatStringHelperImpl const&>::type, std::type_identity::type>, DB::SettingFieldNumber const&, unsigned long&) @ 0x000000002c8b2c5a 4. ./build_docker/./src/Storages/MergeTree/MergeTreeSettings.cpp:0: DB::MergeTreeSettings::sanityCheck(unsigned long) const @ 0x000000002c84e186 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::MergeTreeData::MergeTreeData(DB::StorageID const&, DB::StorageInMemoryMetadata const&, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>, bool, DB::LoadingStrictnessLevel, std::function) @ 0x000000002c4327b2 6. ./build_docker/./src/Storages/StorageMergeTree.cpp:96: DB::StorageMergeTree::StorageMergeTree(DB::StorageID const&, String const&, DB::StorageInMemoryMetadata const&, DB::LoadingStrictnessLevel, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>) @ 0x000000002cbacb89 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:1460: std::shared_ptr std::allocate_shared[abi:v15007], DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, void>(std::allocator const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&) @ 0x000000002cbabafa 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:962: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000002cba21b8 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 @ 0x000000002b77bf53 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291b9254 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291ac835 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000291c3415 13. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b382fc 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 16. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 20. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 21. asan_thread_start(void*) @ 0x000000000aa43059 22. ? @ 0x00007f35aab92ac3 23. ? @ 0x00007f35aac24850 2025.09.09 15:04:20.459273 [ 2900 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:04:20.598272 [ 2909 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:04:20.659344 [ 17365 ] {e122276e-5210-4b01-9f27-40cabe368eb4} executeQuery: Code: 36. DB::Exception: The value of 'number_of_free_entries_in_pool_to_lower_max_size_of_merge' setting (100) (default values are defined in section of config.xml or the value can be specified per table in SETTINGS section of CREATE TABLE query) is greater than the value of 'background_pool_size'*'background_merges_mutations_concurrency_ratio' (32) (the value is defined in users.xml for default profile). This indicates incorrect configuration because the maximum size of merge will be always lowered. (BAD_ARGUMENTS) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:39032) (comment: 01419_merge_tree_settings_sanity_check.sql) (in query: CREATE TABLE mytable_local (`created` DateTime, `eventday` Date, `user_id` UInt32) ENGINE = MergeTree PARTITION BY toYYYYMM(eventday) ORDER BY (eventday, user_id) SETTINGS number_of_free_entries_in_pool_to_lower_max_size_of_merge = 100, index_granularity = 22919, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = false, max_file_name_length = 0, min_bytes_for_full_part_storage = 356152698, compact_parts_max_bytes_to_buffer = 38258153, compact_parts_max_granules_to_buffer = 123, compact_parts_merge_max_bytes_to_prefetch_part = 10490220, merge_max_block_size = 12241, old_parts_lifetime = 117., 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 = 6599255762, index_granularity_bytes = 29496560, concurrent_part_removal_threshold = 4, allow_vertical_merges_from_compact_to_wide_parts = false, cache_populated_by_fetch = true, marks_compress_block_size = 90374, primary_key_compress_block_size = 70024), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception const&, unsigned long&>(int, FormatStringHelperImpl const&>::type, std::type_identity::type>, DB::SettingFieldNumber const&, unsigned long&) @ 0x000000002c8b2c5a 4. ./build_docker/./src/Storages/MergeTree/MergeTreeSettings.cpp:0: DB::MergeTreeSettings::sanityCheck(unsigned long) const @ 0x000000002c84e208 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::MergeTreeData::MergeTreeData(DB::StorageID const&, DB::StorageInMemoryMetadata const&, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>, bool, DB::LoadingStrictnessLevel, std::function) @ 0x000000002c4327b2 6. ./build_docker/./src/Storages/StorageMergeTree.cpp:96: DB::StorageMergeTree::StorageMergeTree(DB::StorageID const&, String const&, DB::StorageInMemoryMetadata const&, DB::LoadingStrictnessLevel, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>) @ 0x000000002cbacb89 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:1460: std::shared_ptr std::allocate_shared[abi:v15007], DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, void>(std::allocator const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&) @ 0x000000002cbabafa 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:962: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000002cba21b8 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 @ 0x000000002b77bf53 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291b9254 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291ac835 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000291c3415 13. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b382fc 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 16. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 20. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 21. asan_thread_start(void*) @ 0x000000000aa43059 22. ? @ 0x00007f35aab92ac3 23. ? @ 0x00007f35aac24850 2025.09.09 15:04:20.662585 [ 17365 ] {e122276e-5210-4b01-9f27-40cabe368eb4} TCPHandler: Code: 36. DB::Exception: The value of 'number_of_free_entries_in_pool_to_lower_max_size_of_merge' setting (100) (default values are defined in section of config.xml or the value can be specified per table in SETTINGS section of CREATE TABLE query) is greater than the value of 'background_pool_size'*'background_merges_mutations_concurrency_ratio' (32) (the value is defined in users.xml for default profile). This indicates incorrect configuration because the maximum size of merge will be always lowered. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception const&, unsigned long&>(int, FormatStringHelperImpl const&>::type, std::type_identity::type>, DB::SettingFieldNumber const&, unsigned long&) @ 0x000000002c8b2c5a 4. ./build_docker/./src/Storages/MergeTree/MergeTreeSettings.cpp:0: DB::MergeTreeSettings::sanityCheck(unsigned long) const @ 0x000000002c84e208 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::MergeTreeData::MergeTreeData(DB::StorageID const&, DB::StorageInMemoryMetadata const&, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>, bool, DB::LoadingStrictnessLevel, std::function) @ 0x000000002c4327b2 6. ./build_docker/./src/Storages/StorageMergeTree.cpp:96: DB::StorageMergeTree::StorageMergeTree(DB::StorageID const&, String const&, DB::StorageInMemoryMetadata const&, DB::LoadingStrictnessLevel, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>) @ 0x000000002cbacb89 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:1460: std::shared_ptr std::allocate_shared[abi:v15007], DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, void>(std::allocator const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&) @ 0x000000002cbabafa 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:962: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000002cba21b8 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 @ 0x000000002b77bf53 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291b9254 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291ac835 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000291c3415 13. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b382fc 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 16. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 20. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 21. asan_thread_start(void*) @ 0x000000000aa43059 22. ? @ 0x00007f35aab92ac3 23. ? @ 0x00007f35aac24850 2025.09.09 15:04:20.820045 [ 17365 ] {ba204b67-e057-4bf6-91ba-e3db4ccae28d} executeQuery: Code: 36. DB::Exception: The value of 'number_of_free_entries_in_pool_to_execute_optimize_entire_partition' setting (100) (default values are defined in section of config.xml or the value can be specified per table in SETTINGS section of CREATE TABLE query) is greater than the value of 'background_pool_size'*'background_merges_mutations_concurrency_ratio' (32) (the value is defined in users.xml for default profile). This indicates incorrect configuration because the maximum size of merge will be always lowered. (BAD_ARGUMENTS) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:39032) (comment: 01419_merge_tree_settings_sanity_check.sql) (in query: CREATE TABLE mytable_local (`created` DateTime, `eventday` Date, `user_id` UInt32) ENGINE = MergeTree PARTITION BY toYYYYMM(eventday) ORDER BY (eventday, user_id) SETTINGS number_of_free_entries_in_pool_to_execute_optimize_entire_partition = 100, index_granularity = 22919, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = false, max_file_name_length = 0, min_bytes_for_full_part_storage = 356152698, compact_parts_max_bytes_to_buffer = 38258153, compact_parts_max_granules_to_buffer = 123, compact_parts_merge_max_bytes_to_prefetch_part = 10490220, merge_max_block_size = 12241, old_parts_lifetime = 117., 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 = 6599255762, index_granularity_bytes = 29496560, concurrent_part_removal_threshold = 4, allow_vertical_merges_from_compact_to_wide_parts = false, cache_populated_by_fetch = true, marks_compress_block_size = 90374, primary_key_compress_block_size = 70024), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception const&, unsigned long&>(int, FormatStringHelperImpl const&>::type, std::type_identity::type>, DB::SettingFieldNumber const&, unsigned long&) @ 0x000000002c8b2c5a 4. ./build_docker/./src/Storages/MergeTree/MergeTreeSettings.cpp:0: DB::MergeTreeSettings::sanityCheck(unsigned long) const @ 0x000000002c84e28a 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::MergeTreeData::MergeTreeData(DB::StorageID const&, DB::StorageInMemoryMetadata const&, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>, bool, DB::LoadingStrictnessLevel, std::function) @ 0x000000002c4327b2 6. ./build_docker/./src/Storages/StorageMergeTree.cpp:96: DB::StorageMergeTree::StorageMergeTree(DB::StorageID const&, String const&, DB::StorageInMemoryMetadata const&, DB::LoadingStrictnessLevel, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>) @ 0x000000002cbacb89 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:1460: std::shared_ptr std::allocate_shared[abi:v15007], DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, void>(std::allocator const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&) @ 0x000000002cbabafa 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:962: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000002cba21b8 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 @ 0x000000002b77bf53 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291b9254 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291ac835 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000291c3415 13. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b382fc 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 16. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 20. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 21. asan_thread_start(void*) @ 0x000000000aa43059 22. ? @ 0x00007f35aab92ac3 23. ? @ 0x00007f35aac24850 2025.09.09 15:04:20.827994 [ 17365 ] {ba204b67-e057-4bf6-91ba-e3db4ccae28d} TCPHandler: Code: 36. DB::Exception: The value of 'number_of_free_entries_in_pool_to_execute_optimize_entire_partition' setting (100) (default values are defined in section of config.xml or the value can be specified per table in SETTINGS section of CREATE TABLE query) is greater than the value of 'background_pool_size'*'background_merges_mutations_concurrency_ratio' (32) (the value is defined in users.xml for default profile). This indicates incorrect configuration because the maximum size of merge will be always lowered. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception const&, unsigned long&>(int, FormatStringHelperImpl const&>::type, std::type_identity::type>, DB::SettingFieldNumber const&, unsigned long&) @ 0x000000002c8b2c5a 4. ./build_docker/./src/Storages/MergeTree/MergeTreeSettings.cpp:0: DB::MergeTreeSettings::sanityCheck(unsigned long) const @ 0x000000002c84e28a 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::MergeTreeData::MergeTreeData(DB::StorageID const&, DB::StorageInMemoryMetadata const&, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>, bool, DB::LoadingStrictnessLevel, std::function) @ 0x000000002c4327b2 6. ./build_docker/./src/Storages/StorageMergeTree.cpp:96: DB::StorageMergeTree::StorageMergeTree(DB::StorageID const&, String const&, DB::StorageInMemoryMetadata const&, DB::LoadingStrictnessLevel, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>) @ 0x000000002cbacb89 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:1460: std::shared_ptr std::allocate_shared[abi:v15007], DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, void>(std::allocator const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&) @ 0x000000002cbabafa 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:962: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000002cba21b8 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 @ 0x000000002b77bf53 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291b9254 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291ac835 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000291c3415 13. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b382fc 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 16. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 20. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 21. asan_thread_start(void*) @ 0x000000000aa43059 22. ? @ 0x00007f35aab92ac3 23. ? @ 0x00007f35aac24850 2025.09.09 15:04:21.296025 [ 17365 ] {d3f94178-bbdb-4726-bf44-17dd12c83b27} executeQuery: Code: 36. DB::Exception: The value of 'number_of_free_entries_in_pool_to_execute_mutation' setting (100) (default values are defined in section of config.xml or the value can be specified per table in SETTINGS section of CREATE TABLE query) is greater than the value of 'background_pool_size'*'background_merges_mutations_concurrency_ratio' (32) (the value is defined in users.xml for default profile). This indicates incorrect configuration because mutations cannot work with these settings. (BAD_ARGUMENTS) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:39032) (comment: 01419_merge_tree_settings_sanity_check.sql) (in query: ALTER TABLE mytable_local MODIFY SETTING number_of_free_entries_in_pool_to_execute_mutation = 100;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception const&, unsigned long&>(int, FormatStringHelperImpl const&>::type, std::type_identity::type>, DB::SettingFieldNumber const&, unsigned long&) @ 0x000000002c8b2c5a 4. ./build_docker/./src/Storages/MergeTree/MergeTreeSettings.cpp:0: DB::MergeTreeSettings::sanityCheck(unsigned long) const @ 0x000000002c84e186 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::MergeTreeData::changeSettings(std::shared_ptr const&, std::unique_lock&) @ 0x000000002c4a54b4 6. ./build_docker/./src/Storages/StorageMergeTree.cpp:350: DB::StorageMergeTree::alter(DB::AlterCommands const&, std::shared_ptr, std::unique_lock&) @ 0x000000002cbb53ca 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:210: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000029174586 8. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x0000000029170711 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b382fc 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 15:04:21.301509 [ 17365 ] {d3f94178-bbdb-4726-bf44-17dd12c83b27} TCPHandler: Code: 36. DB::Exception: The value of 'number_of_free_entries_in_pool_to_execute_mutation' setting (100) (default values are defined in section of config.xml or the value can be specified per table in SETTINGS section of CREATE TABLE query) is greater than the value of 'background_pool_size'*'background_merges_mutations_concurrency_ratio' (32) (the value is defined in users.xml for default profile). This indicates incorrect configuration because mutations cannot work with these settings. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception const&, unsigned long&>(int, FormatStringHelperImpl const&>::type, std::type_identity::type>, DB::SettingFieldNumber const&, unsigned long&) @ 0x000000002c8b2c5a 4. ./build_docker/./src/Storages/MergeTree/MergeTreeSettings.cpp:0: DB::MergeTreeSettings::sanityCheck(unsigned long) const @ 0x000000002c84e186 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::MergeTreeData::changeSettings(std::shared_ptr const&, std::unique_lock&) @ 0x000000002c4a54b4 6. ./build_docker/./src/Storages/StorageMergeTree.cpp:350: DB::StorageMergeTree::alter(DB::AlterCommands const&, std::shared_ptr, std::unique_lock&) @ 0x000000002cbb53ca 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:210: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000029174586 8. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x0000000029170711 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b382fc 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 15:04:21.463111 [ 2923 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:04:21.601660 [ 2934 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:04:22.466237 [ 2948 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:04:22.604703 [ 2958 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:04:22.618720 [ 17365 ] {811f066d-c525-4e94-810b-c350db2a87c6} executeQuery: Code: 1. DB::Exception: Recursive lambda x -> (lambda(1) + x) AS lambda. In scope x -> (lambda(1) + x) AS lambda. (UNSUPPORTED_METHOD) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:39050) (comment: 02388_analyzer_recursive_lambda.sql) (in query: WITH x -> plus(lambda(1), x) AS lambda SELECT lambda(1048576);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa91e9a 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2498: DB::QueryAnalyzer::resolveLambda(std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, DB::IdentifierResolveScope&) @ 0x00000000283ad8f7 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283954e5 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000028367bce 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028366290 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2813: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000028391dce 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000028367bce 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2553: DB::QueryAnalyzer::resolveLambda(std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, DB::IdentifierResolveScope&) @ 0x00000000283ad51b 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283954e5 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000028367bce 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028366290 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283b62c9 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002835ae03 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000028359104 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000028357f0d 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002921bdcc 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&) @ 0x000000002941f313 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&) @ 0x0000000029419aef 21. ./contrib/llvm-project/libcxx/include/vector:432: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000029421f5d 22. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000029344c1b 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*) @ 0x0000000029b3703b 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 25. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 26. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 30. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 31. asan_thread_start(void*) @ 0x000000000aa43059 2025.09.09 15:04:22.627223 [ 17365 ] {811f066d-c525-4e94-810b-c350db2a87c6} TCPHandler: Code: 1. DB::Exception: Recursive lambda x -> (lambda(1) + x) AS lambda. In scope x -> (lambda(1) + x) AS lambda. (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa91e9a 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2498: DB::QueryAnalyzer::resolveLambda(std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, DB::IdentifierResolveScope&) @ 0x00000000283ad8f7 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283954e5 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000028367bce 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028366290 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2813: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000028391dce 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000028367bce 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2553: DB::QueryAnalyzer::resolveLambda(std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, DB::IdentifierResolveScope&) @ 0x00000000283ad51b 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283954e5 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000028367bce 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028366290 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283b62c9 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002835ae03 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000028359104 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000028357f0d 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002921bdcc 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&) @ 0x000000002941f313 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&) @ 0x0000000029419aef 21. ./contrib/llvm-project/libcxx/include/vector:432: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000029421f5d 22. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000029344c1b 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*) @ 0x0000000029b3703b 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 25. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 26. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 30. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 31. asan_thread_start(void*) @ 0x000000000aa43059 2025.09.09 15:04:22.799101 [ 17365 ] {a7e9d616-899c-416e-b109-e4c7a1e730d7} executeQuery: Code: 1. DB::Exception: Recursive lambda x -> plus(lambda(1), x, 2) AS lambda. In scope x -> plus(lambda(1), x, 2) AS lambda. (UNSUPPORTED_METHOD) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:39050) (comment: 02388_analyzer_recursive_lambda.sql) (in query: WITH lambda(lambda(plus(x, x, -1)), tuple(x), x + 2147483646) AS lambda, x -> plus(lambda(1), x, 2) AS lambda SELECT 1048576, lambda(1048576);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa91e9a 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2498: DB::QueryAnalyzer::resolveLambda(std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, DB::IdentifierResolveScope&) @ 0x00000000283ad8f7 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283954e5 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000028367bce 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028366290 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2813: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000028391dce 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000028367bce 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2553: DB::QueryAnalyzer::resolveLambda(std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, DB::IdentifierResolveScope&) @ 0x00000000283ad51b 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283954e5 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000028367bce 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028366290 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283b62c9 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002835ae03 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000028359104 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000028357f0d 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002921bdcc 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&) @ 0x000000002941f313 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&) @ 0x0000000029419aef 21. ./contrib/llvm-project/libcxx/include/vector:432: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000029421f5d 22. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000029344c1b 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*) @ 0x0000000029b3703b 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 25. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 26. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 30. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 31. asan_thread_start(void*) @ 0x000000000aa43059 2025.09.09 15:04:22.807446 [ 17365 ] {a7e9d616-899c-416e-b109-e4c7a1e730d7} TCPHandler: Code: 1. DB::Exception: Recursive lambda x -> plus(lambda(1), x, 2) AS lambda. In scope x -> plus(lambda(1), x, 2) AS lambda. (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa91e9a 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2498: DB::QueryAnalyzer::resolveLambda(std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, DB::IdentifierResolveScope&) @ 0x00000000283ad8f7 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283954e5 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000028367bce 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028366290 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2813: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000028391dce 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000028367bce 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2553: DB::QueryAnalyzer::resolveLambda(std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, DB::IdentifierResolveScope&) @ 0x00000000283ad51b 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283954e5 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000028367bce 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028366290 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283b62c9 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002835ae03 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000028359104 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000028357f0d 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002921bdcc 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&) @ 0x000000002941f313 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&) @ 0x0000000029419aef 21. ./contrib/llvm-project/libcxx/include/vector:432: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000029421f5d 22. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000029344c1b 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*) @ 0x0000000029b3703b 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 25. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 26. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 30. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 31. asan_thread_start(void*) @ 0x000000000aa43059 2025.09.09 15:04:23.468602 [ 2982 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:04:23.608249 [ 2983 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:04:24.526268 [ 2977 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:04:24.611246 [ 2995 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:04:25.485174 [ 3604 ] {f4814756-391d-470c-ba84-72ae87c5f16e} 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.10505.altinitytest (altinity build)) (from [::1]:39064) (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af819ed 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80746 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d34b5ca 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000002d3486e4 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000002d34827b 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002d36bcf7 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 12. asan_thread_start(void*) @ 0x000000000aa43059 13. ? @ 0x00007f35aab92ac3 14. ? @ 0x00007f35aac24850 2025.09.09 15:04:25.515135 [ 3604 ] {f4814756-391d-470c-ba84-72ae87c5f16e} 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af819ed 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80746 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d34b5ca 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000002d3486e4 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000002d34827b 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002d36bcf7 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 12. asan_thread_start(void*) @ 0x000000000aa43059 13. ? @ 0x00007f35aab92ac3 14. ? @ 0x00007f35aac24850 2025.09.09 15:04:25.529354 [ 3024 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:04:25.613621 [ 3025 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:04:26.531814 [ 3051 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:04:26.616401 [ 3053 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:04:27.536226 [ 3074 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:04:27.619233 [ 3082 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:04:28.539472 [ 3081 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:04:28.621984 [ 3121 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:04:29.542419 [ 3150 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:04:29.624871 [ 3146 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:04:30.544787 [ 3169 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:04:30.627007 [ 3175 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:04:31.548008 [ 3200 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:04:31.629711 [ 3199 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:04:32.557466 [ 3225 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:04:32.633003 [ 3218 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:04:33.560262 [ 2733 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:04:33.636043 [ 2736 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:04:34.313460 [ 3612 ] {3fe62ca5-9adc-452d-908f-232938cb309a} executeQuery: Code: 107. DB::Exception: File /var/lib/clickhouse/user_files/nonexist.txt doesn't exist. (FILE_DOESNT_EXIST) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:60216) (in query: select _path,_file from file('nonexist.txt', 'CSV', 'val1 char')), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 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) @ 0x000000002b79db62 5. ./build_docker/./src/Planner/PlannerJoinTree.cpp:880: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x0000000029469c4b 6. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1795: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000002945d99d 7. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x000000002942c986 8. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x00000000294261fb 9. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000029421552 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1182: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3737e 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 13. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 18. asan_thread_start(void*) @ 0x000000000aa43059 19. ? @ 0x00007f35aab92ac3 20. ? @ 0x00007f35aac24850 2025.09.09 15:04:34.316982 [ 3612 ] {3fe62ca5-9adc-452d-908f-232938cb309a} TCPHandler: Code: 107. DB::Exception: File /var/lib/clickhouse/user_files/nonexist.txt doesn't exist. (FILE_DOESNT_EXIST), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 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) @ 0x000000002b79db62 5. ./build_docker/./src/Planner/PlannerJoinTree.cpp:880: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x0000000029469c4b 6. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1795: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000002945d99d 7. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x000000002942c986 8. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x00000000294261fb 9. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000029421552 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1182: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3737e 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 13. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 18. asan_thread_start(void*) @ 0x000000000aa43059 19. ? @ 0x00007f35aab92ac3 20. ? @ 0x00007f35aac24850 2025.09.09 15:04:34.562796 [ 2748 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:04:34.643372 [ 2739 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:04:35.565575 [ 2781 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:04:35.646450 [ 2788 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:04:36.374827 [ 3334 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {ccc63915-230c-46e1-a015-6f55b3fb64ee::202509_1_136_27}: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=13, 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af80b71 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80746 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002c765aab 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:1197: ? @ 0x000000002c7602b8 8. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x000000002c75fc2b 9. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:0: DB::MergeTreeReaderCompact::MergeTreeReaderCompact(std::shared_ptr, DB::NamesAndTypesList, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*, DB::MarkCache*, DB::MarkRanges, DB::MergeTreeReaderSettings, std::map, std::allocator>>, std::function const&, int) @ 0x000000002c7aee03 10. ./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.h:16: DB::MergeTreeReaderCompactSingleBuffer::MergeTreeReaderCompactSingleBuffer&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int&&) @ 0x000000002c5d6d21 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::MergeTreeDataPartCompact::getReader(DB::NamesAndTypesList const&, std::shared_ptr const&, DB::MarkRanges const&, std::unordered_map, std::equal_to, std::allocator>> const&, DB::UncompressedCache*, DB::MarkCache*, std::shared_ptr const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) const @ 0x000000002c5d1037 12. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:169: DB::MergeTreeSequentialSource::MergeTreeSequentialSource(DB::MergeTreeSequentialSourceType, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::vector>, std::optional, bool, bool, bool) @ 0x000000002c80c330 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:35: DB::MergeTreeSequentialSource* std::construct_at[abi:v15007] const&, std::shared_ptr&, std::shared_ptr&, std::vector>&, std::optional, bool, bool&, bool&, DB::MergeTreeSequentialSource*>(DB::MergeTreeSequentialSource*, DB::MergeTreeSequentialSourceType&, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr&, std::shared_ptr&, std::vector>&, std::optional&&, bool&&, bool&, bool&) @ 0x000000002c81320f 14. ./contrib/llvm-project/libcxx/include/__memory/allocator_traits.h:298: DB::createMergeTreeSequentialSource(DB::MergeTreeSequentialSourceType, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::vector>, std::optional, std::shared_ptr>, bool, bool, bool) @ 0x000000002c810812 15. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1136: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::createMergedStream() @ 0x000000002c3dd079 16. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() @ 0x000000002c3d6516 17. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:534: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x000000002c3e2799 18. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::execute() @ 0x000000002c3ef3fe 19. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:0: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000002cc2f4c0 20. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000002c427f28 21. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000002c429675 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7eaf0 23. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001af8a79f 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 26. asan_thread_start(void*) @ 0x000000000aa43059 27. ? @ 0x00007f35aab92ac3 28. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:04:36.568419 [ 2804 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:04:36.657065 [ 2810 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:04:37.571124 [ 2839 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:04:37.659859 [ 2847 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:04:38.574549 [ 2857 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:04:38.663011 [ 2869 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:04:39.092512 [ 3612 ] {c02bdd88-99fd-4407-ab61-91c7f5b5d533} 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.10505.altinitytest (altinity build)) (from [::1]:38880) (comment: 02290_client_insert_cancel.sh) (in query: select count() from system.processes where query_id = '02290_client_insert_cancel_test_3'), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af819ed 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80746 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d34b5ca 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000002d3486e4 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000002d34827b 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002d36bcf7 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 12. asan_thread_start(void*) @ 0x000000000aa43059 13. ? @ 0x00007f35aab92ac3 14. ? @ 0x00007f35aac24850 2025.09.09 15:04:39.103957 [ 3612 ] {c02bdd88-99fd-4407-ab61-91c7f5b5d533} 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af819ed 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80746 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d34b5ca 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000002d3486e4 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000002d34827b 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002d36bcf7 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 12. asan_thread_start(void*) @ 0x000000000aa43059 13. ? @ 0x00007f35aab92ac3 14. ? @ 0x00007f35aac24850 2025.09.09 15:04:39.577545 [ 2887 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:04:39.665686 [ 2883 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:04:40.580912 [ 2914 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:04:40.670086 [ 2918 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:04:41.583939 [ 2929 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:04:41.672876 [ 2941 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:04:42.588120 [ 2968 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:04:42.675905 [ 2963 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:04:43.590664 [ 2985 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:04:43.678266 [ 2998 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:04:44.592706 [ 3001 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:04:44.680854 [ 3015 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:04:45.594909 [ 3031 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:04:45.683377 [ 3044 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:04:46.597144 [ 3033 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:04:46.685682 [ 3061 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:04:47.599389 [ 3068 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:04:47.688090 [ 3043 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:04:48.435181 [ 3612 ] {c8ffcb24-209a-4f07-ab2e-46b2e617066d} executeQuery: Code: 48. DB::Exception: JOIN ON constant supported only with join algorithm 'hash'. (NOT_IMPLEMENTED) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:38946) (comment: 02001_join_on_const_bs_long.gen.sql) (in query: SELECT count() == 2222 FROM t1 JOIN t2 ON 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aac868e 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&) @ 0x00000000294a6ea5 5. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1490: DB::(anonymous namespace)::buildQueryPlanForJoinNode(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000002947642f 6. ./build_docker/./src/Planner/PlannerJoinTree.cpp:0: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000002945f174 7. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x000000002942c986 8. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x00000000294261fb 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::getSampleBlock(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000294204da 10. ./build_docker/./src/Interpreters/ClusterProxy/executeQuery.cpp:680: DB::ClusterProxy::executeQueryWithParallelReplicas(DB::QueryPlan&, DB::StorageID const&, DB::QueryProcessingStage::Enum, std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr> const>, std::unique_ptr>) @ 0x000000002aaaf096 11. ./build_docker/./src/Planner/PlannerJoinTree.cpp:996: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x000000002946e7d2 12. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1795: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000002945d99d 13. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x000000002942c986 14. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x00000000294261fb 15. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000029421552 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1182: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3737e 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 19. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 23. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 24. asan_thread_start(void*) @ 0x000000000aa43059 25. ? @ 0x00007f35aab92ac3 26. ? @ 0x00007f35aac24850 2025.09.09 15:04:48.438271 [ 3612 ] {c8ffcb24-209a-4f07-ab2e-46b2e617066d} 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aac868e 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&) @ 0x00000000294a6ea5 5. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1490: DB::(anonymous namespace)::buildQueryPlanForJoinNode(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000002947642f 6. ./build_docker/./src/Planner/PlannerJoinTree.cpp:0: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000002945f174 7. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x000000002942c986 8. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x00000000294261fb 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::getSampleBlock(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x00000000294204da 10. ./build_docker/./src/Interpreters/ClusterProxy/executeQuery.cpp:680: DB::ClusterProxy::executeQueryWithParallelReplicas(DB::QueryPlan&, DB::StorageID const&, DB::QueryProcessingStage::Enum, std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr> const>, std::unique_ptr>) @ 0x000000002aaaf096 11. ./build_docker/./src/Planner/PlannerJoinTree.cpp:996: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x000000002946e7d2 12. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1795: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000002945d99d 13. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x000000002942c986 14. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x00000000294261fb 15. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000029421552 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1182: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3737e 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 19. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 23. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 24. asan_thread_start(void*) @ 0x000000000aa43059 25. ? @ 0x00007f35aab92ac3 26. ? @ 0x00007f35aac24850 2025.09.09 15:04:48.601362 [ 3096 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:04:48.690965 [ 3102 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:04:49.604474 [ 3115 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:04:49.693190 [ 3123 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:04:50.428257 [ 3612 ] {57801eeb-b40d-418f-a0c0-52b04ef54584} executeQuery: Code: 107. DB::Exception: File /var/lib/clickhouse/user_files/nonexist.txt doesn't exist. (FILE_DOESNT_EXIST) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:46364) (in query: select _path,_file from file('nonexist.txt', 'CSV', 'val1 char')), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 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) @ 0x000000002b79db62 5. ./build_docker/./src/Planner/PlannerJoinTree.cpp:880: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x0000000029469c4b 6. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1795: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000002945d99d 7. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x000000002942c986 8. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x00000000294261fb 9. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000029421552 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1182: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3737e 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 13. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 18. asan_thread_start(void*) @ 0x000000000aa43059 19. ? @ 0x00007f35aab92ac3 20. ? @ 0x00007f35aac24850 2025.09.09 15:04:50.431053 [ 3612 ] {57801eeb-b40d-418f-a0c0-52b04ef54584} TCPHandler: Code: 107. DB::Exception: File /var/lib/clickhouse/user_files/nonexist.txt doesn't exist. (FILE_DOESNT_EXIST), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 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) @ 0x000000002b79db62 5. ./build_docker/./src/Planner/PlannerJoinTree.cpp:880: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x0000000029469c4b 6. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1795: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000002945d99d 7. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x000000002942c986 8. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x00000000294261fb 9. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000029421552 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1182: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3737e 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 13. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 18. asan_thread_start(void*) @ 0x000000000aa43059 19. ? @ 0x00007f35aab92ac3 20. ? @ 0x00007f35aac24850 2025.09.09 15:04:50.613882 [ 3146 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:04:50.695141 [ 3140 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:04:51.615841 [ 3149 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:04:51.697135 [ 3175 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:04:52.617625 [ 3196 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:04:52.699353 [ 3208 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:04:53.619517 [ 3223 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:04:53.701477 [ 3237 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:04:54.621643 [ 2767 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:04:54.703589 [ 2762 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:04:54.817337 [ 17365 ] {a9782936-7d77-4107-b184-6bae1b529766} executeQuery: Code: 36. DB::Exception: User name ' INTERSERVER SECRET ' is reserved. (BAD_ARGUMENTS) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:46400) (comment: 01119_weird_user_names.sql) (in query: create user ` INTERSERVER SECRET `;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Access/User.cpp:0: DB::User::setName(String const&) @ 0x0000000026fbc76e 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::(anonymous namespace)::updateUserFromQueryImpl(DB::User&, DB::ASTCreateUserQuery const&, std::optional, std::shared_ptr const&, std::optional const&, std::optional const&, std::optional const&, std::optional const&, bool, bool, bool) @ 0x000000002aa3b738 6. ./build_docker/./src/Interpreters/Access/InterpreterCreateUserQuery.cpp:229: DB::InterpreterCreateUserQuery::execute() @ 0x000000002aa39427 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b382fc 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 15. asan_thread_start(void*) @ 0x000000000aa43059 16. ? @ 0x00007f35aab92ac3 17. ? @ 0x00007f35aac24850 2025.09.09 15:04:54.821997 [ 17365 ] {a9782936-7d77-4107-b184-6bae1b529766} TCPHandler: Code: 36. DB::Exception: User name ' INTERSERVER SECRET ' is reserved. (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Access/User.cpp:0: DB::User::setName(String const&) @ 0x0000000026fbc76e 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::(anonymous namespace)::updateUserFromQueryImpl(DB::User&, DB::ASTCreateUserQuery const&, std::optional, std::shared_ptr const&, std::optional const&, std::optional const&, std::optional const&, std::optional const&, bool, bool, bool) @ 0x000000002aa3b738 6. ./build_docker/./src/Interpreters/Access/InterpreterCreateUserQuery.cpp:229: DB::InterpreterCreateUserQuery::execute() @ 0x000000002aa39427 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b382fc 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 15. asan_thread_start(void*) @ 0x000000000aa43059 16. ? @ 0x00007f35aab92ac3 17. ? @ 0x00007f35aac24850 2025.09.09 15:04:55.206979 [ 17365 ] {0d9b2e4d-9f13-4545-aba7-236d62caa825} executeQuery: Code: 36. DB::Exception: User name ' INTERSERVER SECRET ' is reserved. (BAD_ARGUMENTS) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:46400) (comment: 01119_weird_user_names.sql) (in query: alter user " spaces " rename to " INTERSERVER SECRET ";), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Access/User.cpp:0: DB::User::setName(String const&) @ 0x0000000026fbc76e 5. ./build_docker/./src/Interpreters/Access/InterpreterCreateUserQuery.cpp:0: DB::(anonymous namespace)::updateUserFromQueryImpl(DB::User&, DB::ASTCreateUserQuery const&, std::optional, std::shared_ptr const&, std::optional const&, std::optional const&, std::optional const&, std::optional const&, bool, bool, bool) @ 0x000000002aa3b7d8 6. ./build_docker/./src/Interpreters/Access/InterpreterCreateUserQuery.cpp:209: std::shared_ptr std::__function::__policy_invoker (std::shared_ptr const&)>::__call_impl (std::shared_ptr const&)>>(std::__function::__policy_storage const*, std::shared_ptr const&) @ 0x000000002aa3e014 7. ./build_docker/./src/Access/MultipleAccessStorage.cpp:419: DB::MultipleAccessStorage::updateImpl(StrongTypedef, DB::UUIDTag> const&, std::function (std::shared_ptr const&)> const&, bool) @ 0x0000000026efcdf3 8. ./build_docker/./src/Access/AccessControl.cpp:568: DB::AccessControl::updateImpl(StrongTypedef, DB::UUIDTag> const&, std::function (std::shared_ptr const&)> const&, bool) @ 0x0000000026d2bc8f 9. ./build_docker/./src/Access/IAccessStorage.cpp:407: DB::IAccessStorage::update(std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>> const&, std::function (std::shared_ptr const&)> const&, bool) @ 0x0000000026e8476e 10. ./contrib/llvm-project/libcxx/include/vector:590: DB::InterpreterCreateUserQuery::execute() @ 0x000000002aa39771 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b382fc 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 14. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 19. asan_thread_start(void*) @ 0x000000000aa43059 20. ? @ 0x00007f35aab92ac3 21. ? @ 0x00007f35aac24850 2025.09.09 15:04:55.209245 [ 17365 ] {0d9b2e4d-9f13-4545-aba7-236d62caa825} TCPHandler: Code: 36. DB::Exception: User name ' INTERSERVER SECRET ' is reserved. (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Access/User.cpp:0: DB::User::setName(String const&) @ 0x0000000026fbc76e 5. ./build_docker/./src/Interpreters/Access/InterpreterCreateUserQuery.cpp:0: DB::(anonymous namespace)::updateUserFromQueryImpl(DB::User&, DB::ASTCreateUserQuery const&, std::optional, std::shared_ptr const&, std::optional const&, std::optional const&, std::optional const&, std::optional const&, bool, bool, bool) @ 0x000000002aa3b7d8 6. ./build_docker/./src/Interpreters/Access/InterpreterCreateUserQuery.cpp:209: std::shared_ptr std::__function::__policy_invoker (std::shared_ptr const&)>::__call_impl (std::shared_ptr const&)>>(std::__function::__policy_storage const*, std::shared_ptr const&) @ 0x000000002aa3e014 7. ./build_docker/./src/Access/MultipleAccessStorage.cpp:419: DB::MultipleAccessStorage::updateImpl(StrongTypedef, DB::UUIDTag> const&, std::function (std::shared_ptr const&)> const&, bool) @ 0x0000000026efcdf3 8. ./build_docker/./src/Access/AccessControl.cpp:568: DB::AccessControl::updateImpl(StrongTypedef, DB::UUIDTag> const&, std::function (std::shared_ptr const&)> const&, bool) @ 0x0000000026d2bc8f 9. ./build_docker/./src/Access/IAccessStorage.cpp:407: DB::IAccessStorage::update(std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>> const&, std::function (std::shared_ptr const&)> const&, bool) @ 0x0000000026e8476e 10. ./contrib/llvm-project/libcxx/include/vector:590: DB::InterpreterCreateUserQuery::execute() @ 0x000000002aa39771 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b382fc 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 14. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 19. asan_thread_start(void*) @ 0x000000000aa43059 20. ? @ 0x00007f35aab92ac3 21. ? @ 0x00007f35aac24850 2025.09.09 15:04:55.623756 [ 2783 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:04:55.705698 [ 2794 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:04:56.629613 [ 2804 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:04:56.755005 [ 2829 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:04:57.005246 [ 13328 ] {92283296-0356-4a98-862d-16d0797d0c7c} executeQuery: Code: 57. DB::Exception: Table test_w6mkv0ng.table_map already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:46416) (comment: 01550_create_map_type.sql) (in query: CREATE TABLE table_map (`d` DATE, `m` Map(Int8, UInt256)) ENGINE = MergeTree ORDER BY d SETTINGS index_granularity = 8192, index_granularity_bytes = '10Mi', min_bytes_for_wide_part = 1073741824, ratio_of_defaults_for_sparse_serialization = 0., replace_long_file_name_to_hash = false, max_file_name_length = 86, min_bytes_for_full_part_storage = 445508150, compact_parts_max_bytes_to_buffer = 408463336, compact_parts_max_granules_to_buffer = 152, compact_parts_merge_max_bytes_to_prefetch_part = 8053791, merge_max_block_size = 23915, 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 = 27, min_merge_bytes_to_use_direct_io = 1, concurrent_part_removal_threshold = 21, allow_vertical_merges_from_compact_to_wide_parts = false, cache_populated_by_fetch = false, marks_compress_block_size = 53389, primary_key_compress_block_size = 22504), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa91e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1558: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291bc5ff 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291ac835 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000291c3415 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b382fc 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 15. asan_thread_start(void*) @ 0x000000000aa43059 16. ? @ 0x00007f35aab92ac3 17. ? @ 0x00007f35aac24850 2025.09.09 15:04:57.007549 [ 13328 ] {92283296-0356-4a98-862d-16d0797d0c7c} TCPHandler: Code: 57. DB::Exception: Table test_w6mkv0ng.table_map already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa91e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1558: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291bc5ff 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291ac835 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000291c3415 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b382fc 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 15. asan_thread_start(void*) @ 0x000000000aa43059 16. ? @ 0x00007f35aab92ac3 17. ? @ 0x00007f35aac24850 2025.09.09 15:04:57.318788 [ 4025 ] {92f49745-0930-41f9-b676-af6b76cf3104} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:47450) (comment: 01550_create_map_type.sql) (in query: DROP DATABASE IF EXISTS test_w6mkv0ng ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aac868e 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x00000000286b57c7 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x00000000291f5630 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:361: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000291edc97 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x00000000291ebf11 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x00000000291eb7ed 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b382fc 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1529: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000029b3ed3f 11. ./build_docker/./src/Server/HTTPHandler.cpp:529: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000002d0662d1 12. ./build_docker/./src/Server/HTTPHandler.cpp:705: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000002d06d139 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000002d1cc337 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 18. asan_thread_start(void*) @ 0x000000000aa43059 19. ? @ 0x00007f35aab92ac3 20. ? @ 0x00007f35aac24850 2025.09.09 15:04:57.321759 [ 4025 ] {92f49745-0930-41f9-b676-af6b76cf3104} DynamicQueryHandler: Code: 219. DB::Exception: New table 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aac868e 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x00000000286b57c7 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x00000000291f5630 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:361: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000291edc97 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x00000000291ebf11 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x00000000291eb7ed 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b382fc 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1529: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000029b3ed3f 11. ./build_docker/./src/Server/HTTPHandler.cpp:529: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000002d0662d1 12. ./build_docker/./src/Server/HTTPHandler.cpp:705: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000002d06d139 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000002d1cc337 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 18. asan_thread_start(void*) @ 0x000000000aa43059 19. ? @ 0x00007f35aab92ac3 20. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:04:57.330797 [ 17365 ] {4a435fdc-4ffe-47e3-8fdb-21a8f00f47bb} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=773, jobs=736). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:46442) (comment: 00538_datediff.sql) (in query: SELECT dateDiff('year', toDate('2017-12-31'), toDate('2017-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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af872f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af7b2d1 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af7c3f3 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d36920d 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000002d369e5f 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processOrdinaryQuery() @ 0x000000002d18af7b 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d17644a 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 15. asan_thread_start(void*) @ 0x000000000aa43059 16. ? @ 0x00007f35aab92ac3 17. ? @ 0x00007f35aac24850 2025.09.09 15:04:57.335437 [ 17365 ] {4a435fdc-4ffe-47e3-8fdb-21a8f00f47bb} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=773, jobs=736). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af872f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af7b2d1 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af7c3f3 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d36920d 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000002d369e5f 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processOrdinaryQuery() @ 0x000000002d18af7b 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d17644a 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 15. asan_thread_start(void*) @ 0x000000000aa43059 16. ? @ 0x00007f35aab92ac3 17. ? @ 0x00007f35aac24850 2025.09.09 15:04:57.465514 [ 3612 ] {b9cd227f-01e5-43e3-9368-eaab16eb6f62} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:47454) (comment: 01550_create_map_type.sql) (in query: DROP DATABASE IF EXISTS test_w6mkv0ng ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aac868e 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x00000000286b57c7 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x00000000291f5630 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:361: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000291edc97 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x00000000291ebf11 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x00000000291eb7ed 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b382fc 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1529: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000029b3ed3f 11. ./build_docker/./src/Server/HTTPHandler.cpp:529: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000002d0662d1 12. ./build_docker/./src/Server/HTTPHandler.cpp:705: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000002d06d139 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000002d1cc337 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 18. asan_thread_start(void*) @ 0x000000000aa43059 19. ? @ 0x00007f35aab92ac3 20. ? @ 0x00007f35aac24850 2025.09.09 15:04:57.469685 [ 3612 ] {b9cd227f-01e5-43e3-9368-eaab16eb6f62} DynamicQueryHandler: Code: 219. DB::Exception: New table 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aac868e 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x00000000286b57c7 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x00000000291f5630 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:361: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000291edc97 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x00000000291ebf11 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x00000000291eb7ed 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b382fc 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1529: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000029b3ed3f 11. ./build_docker/./src/Server/HTTPHandler.cpp:529: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000002d0662d1 12. ./build_docker/./src/Server/HTTPHandler.cpp:705: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000002d06d139 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000002d1cc337 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 18. asan_thread_start(void*) @ 0x000000000aa43059 19. ? @ 0x00007f35aab92ac3 20. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:04:57.592981 [ 4025 ] {87efb6c8-b2ec-4ad6-bbfe-0380c07c7ab8} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:47464) (comment: 01550_create_map_type.sql) (in query: DROP DATABASE IF EXISTS test_w6mkv0ng ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aac868e 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x00000000286b57c7 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x00000000291f5630 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:361: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000291edc97 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x00000000291ebf11 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x00000000291eb7ed 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b382fc 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1529: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000029b3ed3f 11. ./build_docker/./src/Server/HTTPHandler.cpp:529: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000002d0662d1 12. ./build_docker/./src/Server/HTTPHandler.cpp:705: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000002d06d139 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000002d1cc337 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 18. asan_thread_start(void*) @ 0x000000000aa43059 19. ? @ 0x00007f35aab92ac3 20. ? @ 0x00007f35aac24850 2025.09.09 15:04:57.602317 [ 4025 ] {87efb6c8-b2ec-4ad6-bbfe-0380c07c7ab8} DynamicQueryHandler: Code: 219. DB::Exception: New table 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aac868e 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x00000000286b57c7 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x00000000291f5630 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:361: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000291edc97 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x00000000291ebf11 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x00000000291eb7ed 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b382fc 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1529: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000029b3ed3f 11. ./build_docker/./src/Server/HTTPHandler.cpp:529: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000002d0662d1 12. ./build_docker/./src/Server/HTTPHandler.cpp:705: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000002d06d139 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000002d1cc337 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 18. asan_thread_start(void*) @ 0x000000000aa43059 19. ? @ 0x00007f35aab92ac3 20. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:04:57.632075 [ 2842 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:04:57.757998 [ 2835 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:04:58.635012 [ 2861 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:04:58.759958 [ 2862 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:04:59.015847 [ 4025 ] {be097656-0a06-4327-8e46-0300227ada02} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=773, jobs=736). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:46452) (comment: 03094_analyzer_fiddle_multiif.sql) (in query: SELECT multiIf((age > 30) or (true), '1', '2') AS a, max(name) FROM users_03094 GROUP BY a;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af872f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af7b2d1 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af7c3f3 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d36920d 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000002d369e5f 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processOrdinaryQuery() @ 0x000000002d18af7b 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d17644a 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 15. asan_thread_start(void*) @ 0x000000000aa43059 16. ? @ 0x00007f35aab92ac3 17. ? @ 0x00007f35aac24850 2025.09.09 15:04:59.024934 [ 4025 ] {be097656-0a06-4327-8e46-0300227ada02} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=773, jobs=736). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af872f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af7b2d1 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af7c3f3 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d36920d 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000002d369e5f 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processOrdinaryQuery() @ 0x000000002d18af7b 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d17644a 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 15. asan_thread_start(void*) @ 0x000000000aa43059 16. ? @ 0x00007f35aab92ac3 17. ? @ 0x00007f35aac24850 2025.09.09 15:04:59.637603 [ 2880 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:04:59.762580 [ 2871 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:05:00.171053 [ 4025 ] {777f3095-bb13-4a8f-8ef8-a0f476890874} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=773, jobs=736). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:52456) (comment: 01889_sqlite_read_write.sh) (in query: SHOW CREATE TABLE test_01889_sqllite_test_3.table1;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af872f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af7b2d1 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af7c3f3 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d36920d 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000002d369e5f 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processOrdinaryQuery() @ 0x000000002d18af7b 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d17644a 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 15. asan_thread_start(void*) @ 0x000000000aa43059 16. ? @ 0x00007f35aab92ac3 17. ? @ 0x00007f35aac24850 2025.09.09 15:05:00.198521 [ 4025 ] {777f3095-bb13-4a8f-8ef8-a0f476890874} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=773, jobs=736). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af872f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af7b2d1 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af7c3f3 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d36920d 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000002d369e5f 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processOrdinaryQuery() @ 0x000000002d18af7b 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d17644a 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 15. asan_thread_start(void*) @ 0x000000000aa43059 16. ? @ 0x00007f35aab92ac3 17. ? @ 0x00007f35aac24850 2025.09.09 15:05:00.645527 [ 2904 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:05:00.767515 [ 2914 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:05:01.648698 [ 2936 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:05:01.769465 [ 2932 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:05:02.651017 [ 2988 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:05:02.801201 [ 2983 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:05:03.653989 [ 3008 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:05:03.804525 [ 3026 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:05:04.657479 [ 3035 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:05:04.808175 [ 3007 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:05:05.660264 [ 3045 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:05:05.799899 [ 4025 ] {b8fd79e1-b131-41a4-8e12-d416a2ad06e7} 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.10505.altinitytest (altinity build)) (from [::1]:52560) (comment: 00808_not_optimize_predicate.sql) (in query: SELECT * FROM (SELECT * FROM test_00808 FINAL) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af819ed 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af82f33 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002c64fc80 7. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1723: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr, unsigned long, std::shared_ptr, std::equal_to, std::allocator>>>, DB::MergeTreeData const&, std::vector> const&, std::shared_ptr, std::optional&, bool) @ 0x000000002de379fd 8. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1437: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000002de3554f 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:0: DB::ReadFromMergeTree::getAnalysisResult() const @ 0x000000002de41345 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:2022: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000002de4404c 11. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000002ddb933c 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000002ddff11e 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000002942117f 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x00000000294209e7 15. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b382fc 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 18. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 22. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:05:05.810527 [ 4025 ] {b8fd79e1-b131-41a4-8e12-d416a2ad06e7} 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af819ed 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af82f33 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002c64fc80 7. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1723: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr, unsigned long, std::shared_ptr, std::equal_to, std::allocator>>>, DB::MergeTreeData const&, std::vector> const&, std::shared_ptr, std::optional&, bool) @ 0x000000002de379fd 8. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1437: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000002de3554f 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:0: DB::ReadFromMergeTree::getAnalysisResult() const @ 0x000000002de41345 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:2022: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000002de4404c 11. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000002ddb933c 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000002ddff11e 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000002942117f 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x00000000294209e7 15. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b382fc 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 18. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 22. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:05:05.818473 [ 3033 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:05:06.662522 [ 3043 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:05:06.849797 [ 3090 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:05:07.262492 [ 3329 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {44b09201-5a0e-4da3-91d1-ac60ea8508c5::202509_1_112_31}: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=13, jobs=0). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af80b71 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80746 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002c765aab 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:1197: ? @ 0x000000002c7602b8 8. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x000000002c75fc2b 9. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:0: DB::MergeTreeReaderCompact::MergeTreeReaderCompact(std::shared_ptr, DB::NamesAndTypesList, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*, DB::MarkCache*, DB::MarkRanges, DB::MergeTreeReaderSettings, std::map, std::allocator>>, std::function const&, int) @ 0x000000002c7aee03 10. ./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.h:16: DB::MergeTreeReaderCompactSingleBuffer::MergeTreeReaderCompactSingleBuffer&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int&&) @ 0x000000002c5d6d21 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::MergeTreeDataPartCompact::getReader(DB::NamesAndTypesList const&, std::shared_ptr const&, DB::MarkRanges const&, std::unordered_map, std::equal_to, std::allocator>> const&, DB::UncompressedCache*, DB::MarkCache*, std::shared_ptr const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) const @ 0x000000002c5d1037 12. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:169: DB::MergeTreeSequentialSource::MergeTreeSequentialSource(DB::MergeTreeSequentialSourceType, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::vector>, std::optional, bool, bool, bool) @ 0x000000002c80c330 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:35: DB::MergeTreeSequentialSource* std::construct_at[abi:v15007] const&, std::shared_ptr&, std::shared_ptr&, std::vector>&, std::optional, bool, bool&, bool&, DB::MergeTreeSequentialSource*>(DB::MergeTreeSequentialSource*, DB::MergeTreeSequentialSourceType&, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr&, std::shared_ptr&, std::vector>&, std::optional&&, bool&&, bool&, bool&) @ 0x000000002c81320f 14. ./contrib/llvm-project/libcxx/include/__memory/allocator_traits.h:298: DB::createMergeTreeSequentialSource(DB::MergeTreeSequentialSourceType, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::vector>, std::optional, std::shared_ptr>, bool, bool, bool) @ 0x000000002c810812 15. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1136: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::createMergedStream() @ 0x000000002c3dd079 16. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() @ 0x000000002c3d6516 17. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:534: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x000000002c3e2799 18. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::execute() @ 0x000000002c3ef3fe 19. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:0: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000002cc2f4c0 20. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000002c427f28 21. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000002c429675 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7eaf0 23. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001af8a79f 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 26. asan_thread_start(void*) @ 0x000000000aa43059 27. ? @ 0x00007f35aab92ac3 28. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:05:07.668539 [ 3114 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:05:07.852543 [ 3109 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:05:08.671488 [ 3144 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:05:08.855051 [ 3146 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:05:09.673830 [ 3170 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:05:09.857315 [ 3165 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:05:10.676103 [ 3187 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:05:10.859548 [ 3195 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:05:11.678159 [ 3218 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:05:11.861428 [ 3231 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:05:12.681326 [ 2738 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:05:12.864382 [ 2757 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:05:13.684876 [ 2769 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:05:13.867830 [ 2780 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:05:14.107945 [ 3612 ] {fee2cc32-4af6-414d-aaea-1e7135fbb5f5} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:55644) (comment: 01923_network_receive_time_metric_insert.sh) (in query: DROP DATABASE IF EXISTS test_m89px5p4 ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aac868e 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x00000000286b57c7 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x00000000291f5630 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:361: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000291edc97 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x00000000291ebf11 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x00000000291eb7ed 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b382fc 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1529: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000029b3ed3f 11. ./build_docker/./src/Server/HTTPHandler.cpp:529: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000002d0662d1 12. ./build_docker/./src/Server/HTTPHandler.cpp:705: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000002d06d139 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000002d1cc337 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 18. asan_thread_start(void*) @ 0x000000000aa43059 19. ? @ 0x00007f35aab92ac3 20. ? @ 0x00007f35aac24850 2025.09.09 15:05:14.126466 [ 3612 ] {fee2cc32-4af6-414d-aaea-1e7135fbb5f5} DynamicQueryHandler: Code: 219. DB::Exception: New table 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aac868e 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x00000000286b57c7 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x00000000291f5630 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:361: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000291edc97 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x00000000291ebf11 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x00000000291eb7ed 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b382fc 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1529: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000029b3ed3f 11. ./build_docker/./src/Server/HTTPHandler.cpp:529: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000002d0662d1 12. ./build_docker/./src/Server/HTTPHandler.cpp:705: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000002d06d139 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000002d1cc337 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 18. asan_thread_start(void*) @ 0x000000000aa43059 19. ? @ 0x00007f35aab92ac3 20. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:05:14.304669 [ 4025 ] {1436d74f-3d05-4144-b872-111d1b4cbbc9} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:55652) (comment: 01923_network_receive_time_metric_insert.sh) (in query: DROP DATABASE IF EXISTS test_m89px5p4 ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aac868e 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x00000000286b57c7 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x00000000291f5630 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:361: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000291edc97 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x00000000291ebf11 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x00000000291eb7ed 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b382fc 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1529: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000029b3ed3f 11. ./build_docker/./src/Server/HTTPHandler.cpp:529: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000002d0662d1 12. ./build_docker/./src/Server/HTTPHandler.cpp:705: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000002d06d139 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000002d1cc337 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 18. asan_thread_start(void*) @ 0x000000000aa43059 19. ? @ 0x00007f35aab92ac3 20. ? @ 0x00007f35aac24850 2025.09.09 15:05:14.309927 [ 4025 ] {1436d74f-3d05-4144-b872-111d1b4cbbc9} DynamicQueryHandler: Code: 219. DB::Exception: New table 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aac868e 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x00000000286b57c7 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x00000000291f5630 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:361: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000291edc97 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x00000000291ebf11 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x00000000291eb7ed 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b382fc 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1529: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000029b3ed3f 11. ./build_docker/./src/Server/HTTPHandler.cpp:529: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000002d0662d1 12. ./build_docker/./src/Server/HTTPHandler.cpp:705: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000002d06d139 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000002d1cc337 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 18. asan_thread_start(void*) @ 0x000000000aa43059 19. ? @ 0x00007f35aab92ac3 20. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:05:14.688109 [ 2812 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:05:14.870953 [ 2803 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:05:15.197709 [ 13328 ] {1d85581b-0d56-4fea-aa22-76c155d81244} executeQuery: Code: 591. DB::Exception: Failed to fetch table structure for '); select 1 --. (SQLITE_ENGINE_ERROR) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:46358) (comment: 01889_sqlite_read_write.sh) (in query: SELECT * FROM sqlite('/var/lib/clickhouse/user_files/test_01889_sqllite_test_3_db1', '\'); select 1 --') ORDER BY col2 -- { serverError SQLITE_ENGINE_ERROR }), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageSQLite.cpp:86: DB::StorageSQLite::getTableStructureFromData(std::shared_ptr const&, String const&) @ 0x000000002bc8f71f 5. ./build_docker/./src/Storages/StorageSQLite.cpp:0: DB::StorageSQLite::StorageSQLite(DB::StorageID const&, std::shared_ptr, String const&, String const&, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, String const&, std::shared_ptr) @ 0x000000002bc8ebab 6. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:35: DB::StorageSQLite* std::construct_at[abi:v15007] const&, String const&, String const&, DB::ColumnsDescription&, DB::ConstraintsDescription, char const (&) [1], std::shared_ptr&, DB::StorageSQLite*>(DB::StorageSQLite*, DB::StorageID&&, std::shared_ptr const&, String const&, String const&, DB::ColumnsDescription&, DB::ConstraintsDescription&&, char const (&) [1], std::shared_ptr&) @ 0x0000000026035dd9 7. ./contrib/llvm-project/libcxx/include/__memory/allocator_traits.h:298: std::shared_ptr std::allocate_shared[abi:v15007], DB::StorageID, std::shared_ptr const&, String const&, String const&, DB::ColumnsDescription&, DB::ConstraintsDescription, char const (&) [1], std::shared_ptr&, void>(std::allocator const&, DB::StorageID&&, std::shared_ptr const&, String const&, String const&, DB::ColumnsDescription&, DB::ConstraintsDescription&&, char const (&) [1], std::shared_ptr&) @ 0x00000000260358a0 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:962: DB::(anonymous namespace)::TableFunctionSQLite::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x0000000026035385 9. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x00000000265c241e 10. ./build_docker/./src/Interpreters/Context.cpp:2234: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000285361d2 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4819: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000002837024e 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000283ba404 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002835ad09 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000028359104 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000028357f0d 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002921bdcc 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&) @ 0x000000002941f313 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&) @ 0x0000000029419aef 19. ./contrib/llvm-project/libcxx/include/vector:432: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000029421f5d 20. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000029344c1b 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*) @ 0x0000000029b3703b 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 23. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 24. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 29. asan_thread_start(void*) @ 0x000000000aa43059 30. ? @ 0x00007f35aab92ac3 31. ? @ 0x00007f35aac24850 2025.09.09 15:05:15.201303 [ 13328 ] {1d85581b-0d56-4fea-aa22-76c155d81244} TCPHandler: Code: 591. DB::Exception: Failed to fetch table structure for '); select 1 --. (SQLITE_ENGINE_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageSQLite.cpp:86: DB::StorageSQLite::getTableStructureFromData(std::shared_ptr const&, String const&) @ 0x000000002bc8f71f 5. ./build_docker/./src/Storages/StorageSQLite.cpp:0: DB::StorageSQLite::StorageSQLite(DB::StorageID const&, std::shared_ptr, String const&, String const&, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, String const&, std::shared_ptr) @ 0x000000002bc8ebab 6. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:35: DB::StorageSQLite* std::construct_at[abi:v15007] const&, String const&, String const&, DB::ColumnsDescription&, DB::ConstraintsDescription, char const (&) [1], std::shared_ptr&, DB::StorageSQLite*>(DB::StorageSQLite*, DB::StorageID&&, std::shared_ptr const&, String const&, String const&, DB::ColumnsDescription&, DB::ConstraintsDescription&&, char const (&) [1], std::shared_ptr&) @ 0x0000000026035dd9 7. ./contrib/llvm-project/libcxx/include/__memory/allocator_traits.h:298: std::shared_ptr std::allocate_shared[abi:v15007], DB::StorageID, std::shared_ptr const&, String const&, String const&, DB::ColumnsDescription&, DB::ConstraintsDescription, char const (&) [1], std::shared_ptr&, void>(std::allocator const&, DB::StorageID&&, std::shared_ptr const&, String const&, String const&, DB::ColumnsDescription&, DB::ConstraintsDescription&&, char const (&) [1], std::shared_ptr&) @ 0x00000000260358a0 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:962: DB::(anonymous namespace)::TableFunctionSQLite::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x0000000026035385 9. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x00000000265c241e 10. ./build_docker/./src/Interpreters/Context.cpp:2234: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000285361d2 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4819: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000002837024e 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000283ba404 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002835ad09 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000028359104 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000028357f0d 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002921bdcc 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&) @ 0x000000002941f313 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&) @ 0x0000000029419aef 19. ./contrib/llvm-project/libcxx/include/vector:432: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000029421f5d 20. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000029344c1b 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*) @ 0x0000000029b3703b 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 23. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 24. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 29. asan_thread_start(void*) @ 0x000000000aa43059 30. ? @ 0x00007f35aab92ac3 31. ? @ 0x00007f35aac24850 2025.09.09 15:05:15.691594 [ 2825 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:05:15.873643 [ 2828 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:05:16.354660 [ 2848 ] {} 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af819ed 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80746 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000263a174e 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000286c6b9c 8. ./contrib/llvm-project/libcxx/include/vector:590: DB::DatabaseCatalog::dropTableDataTask() @ 0x00000000286c7466 9. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 11. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 14. asan_thread_start(void*) @ 0x000000000aa43059 15. ? @ 0x00007f35aab92ac3 16. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:05:16.698633 [ 2861 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:05:16.876697 [ 2864 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:05:17.701029 [ 2887 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:05:17.879727 [ 2892 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:05:18.703427 [ 2908 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:05:18.950560 [ 2905 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:05:19.705945 [ 2941 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:05:19.953589 [ 2942 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:05:20.101107 [ 3612 ] {89f31723-ecfb-43cf-8660-1ef7c118ea5e} executeQuery: Code: 43. DB::Exception: Illegal types Array(UInt8) and Array(UInt8) of arguments of function modulo: In scope SELECT [12, 13] % [5, 6]. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:46392) (comment: 02812_pointwise_array_operations.sql) (in query: SELECT ([12,13] % [5,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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000ac6ad20 4. DB::FunctionBinaryArithmetic::getReturnTypeImplStatic(std::vector, std::allocator>> const&, std::shared_ptr) @ 0x00000000152bf1b9 5. DB::BinaryArithmeticOverloadResolver::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x0000000014c7a569 6. DB::IFunctionOverloadResolver::getReturnTypeImpl(std::vector> const&) const @ 0x000000000c2b5b32 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000ccd376e 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000ccd3176 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000ccd4343 10. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000028399ff0 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000028367bce 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028366290 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283b62c9 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002835ae03 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000028359104 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000028357f0d 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002921bdcc 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&) @ 0x000000002941f313 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&) @ 0x0000000029419aef 20. ./contrib/llvm-project/libcxx/include/vector:432: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000029421f5d 21. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000029344c1b 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*) @ 0x0000000029b3703b 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 25. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 29. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 30. asan_thread_start(void*) @ 0x000000000aa43059 31. ? @ 0x00007f35aab92ac3 2025.09.09 15:05:20.105519 [ 3612 ] {89f31723-ecfb-43cf-8660-1ef7c118ea5e} TCPHandler: Code: 43. DB::Exception: Illegal types Array(UInt8) and Array(UInt8) of arguments of function modulo: In scope SELECT [12, 13] % [5, 6]. (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000ac6ad20 4. DB::FunctionBinaryArithmetic::getReturnTypeImplStatic(std::vector, std::allocator>> const&, std::shared_ptr) @ 0x00000000152bf1b9 5. DB::BinaryArithmeticOverloadResolver::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x0000000014c7a569 6. DB::IFunctionOverloadResolver::getReturnTypeImpl(std::vector> const&) const @ 0x000000000c2b5b32 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000ccd376e 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000ccd3176 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000ccd4343 10. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000028399ff0 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000028367bce 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028366290 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283b62c9 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002835ae03 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000028359104 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000028357f0d 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002921bdcc 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&) @ 0x000000002941f313 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&) @ 0x0000000029419aef 20. ./contrib/llvm-project/libcxx/include/vector:432: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000029421f5d 21. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000029344c1b 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*) @ 0x0000000029b3703b 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 25. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 29. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 30. asan_thread_start(void*) @ 0x000000000aa43059 31. ? @ 0x00007f35aab92ac3 2025.09.09 15:05:20.393602 [ 3612 ] {ef335df0-fe37-469c-bea0-d4ae6ad327e7} executeQuery: Code: 190. DB::Exception: Two arguments for function minus must have equal sizes: In scope SELECT [2, 3, 4] - [1, -2, 10, 29]. (SIZES_OF_ARRAYS_DONT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:46392) (comment: 02812_pointwise_array_operations.sql) (in query: SELECT ([2,3,4]-[1,-2,10,29]);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000aad4b34 4. DB::FunctionBinaryArithmetic::executeArraysImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000149ab688 5. DB::FunctionBinaryArithmetic::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const @ 0x00000000149a28f9 6. DB::FunctionBinaryArithmetic::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001499e573 7. DB::FunctionBinaryArithmeticWithConstants::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001499b389 8. DB::FunctionBinaryArithmetic::executeArraysImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000149ab163 9. DB::FunctionBinaryArithmetic::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const @ 0x00000000149a28f9 10. DB::FunctionBinaryArithmetic::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001499e573 11. DB::FunctionBinaryArithmeticWithConstants::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001499b389 12. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aa8c635 13. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aac91d5 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000cccccfb 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccce65c 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd2030 17. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002839a3af 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000028367bce 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028366290 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283b62c9 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002835ae03 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000028359104 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000028357f0d 24. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002921bdcc 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&) @ 0x000000002941f313 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&) @ 0x0000000029419aef 27. ./contrib/llvm-project/libcxx/include/vector:432: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000029421f5d 28. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000029344c1b 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*) @ 0x0000000029b3703b 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 31. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 2025.09.09 15:05:20.413398 [ 3612 ] {ef335df0-fe37-469c-bea0-d4ae6ad327e7} TCPHandler: Code: 190. DB::Exception: Two arguments for function minus must have equal sizes: In scope SELECT [2, 3, 4] - [1, -2, 10, 29]. (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000aad4b34 4. DB::FunctionBinaryArithmetic::executeArraysImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000149ab688 5. DB::FunctionBinaryArithmetic::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const @ 0x00000000149a28f9 6. DB::FunctionBinaryArithmetic::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001499e573 7. DB::FunctionBinaryArithmeticWithConstants::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001499b389 8. DB::FunctionBinaryArithmetic::executeArraysImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000149ab163 9. DB::FunctionBinaryArithmetic::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const @ 0x00000000149a28f9 10. DB::FunctionBinaryArithmetic::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001499e573 11. DB::FunctionBinaryArithmeticWithConstants::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001499b389 12. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aa8c635 13. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aac91d5 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000cccccfb 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccce65c 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd2030 17. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002839a3af 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000028367bce 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028366290 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283b62c9 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002835ae03 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000028359104 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000028357f0d 24. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002921bdcc 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&) @ 0x000000002941f313 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&) @ 0x0000000029419aef 27. ./contrib/llvm-project/libcxx/include/vector:432: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000029421f5d 28. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000029344c1b 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*) @ 0x0000000029b3703b 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 31. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 2025.09.09 15:05:20.708393 [ 2972 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:05:20.956799 [ 2978 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:05:21.052208 [ 3612 ] {6bfd3a7f-9146-4c08-9525-a400f3951c75} executeQuery: Code: 190. DB::Exception: Two arguments for function plus must have equal sizes: while executing 'FUNCTION plus(__table1.x :: 2, __table1.y : 0) -> plus(__table1.x, __table1.y) Array(UInt64) : 3'. (SIZES_OF_ARRAYS_DONT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:46392) (comment: 02812_pointwise_array_operations.sql) (in query: SELECT x, y, x+y FROM a;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000aad4b34 4. DB::FunctionBinaryArithmetic::executeArraysImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000016eb8308 5. DB::FunctionBinaryArithmetic::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const @ 0x0000000016eaf579 6. DB::FunctionBinaryArithmetic::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000016eaa986 7. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aac9135 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000cccce5b 9. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccce65c 10. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd2030 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x00000000286fc2bd 12. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000002d9c29ae 13. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 14. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 15. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000002d34877c 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000002d34827b 19. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002d36bcf7 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 22. asan_thread_start(void*) @ 0x000000000aa43059 23. ? @ 0x00007f35aab92ac3 24. ? @ 0x00007f35aac24850 2025.09.09 15:05:21.067268 [ 3612 ] {6bfd3a7f-9146-4c08-9525-a400f3951c75} TCPHandler: Code: 190. DB::Exception: Two arguments for function plus must have equal sizes: while executing 'FUNCTION plus(__table1.x :: 2, __table1.y : 0) -> plus(__table1.x, __table1.y) Array(UInt64) : 3'. (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000aad4b34 4. DB::FunctionBinaryArithmetic::executeArraysImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000016eb8308 5. DB::FunctionBinaryArithmetic::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const @ 0x0000000016eaf579 6. DB::FunctionBinaryArithmetic::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000016eaa986 7. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aac9135 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000cccce5b 9. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccce65c 10. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd2030 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x00000000286fc2bd 12. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000002d9c29ae 13. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 14. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 15. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000002d34877c 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000002d34827b 19. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002d36bcf7 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 22. asan_thread_start(void*) @ 0x000000000aa43059 23. ? @ 0x00007f35aab92ac3 24. ? @ 0x00007f35aac24850 2025.09.09 15:05:21.387338 [ 13328 ] {f6228635-2214-459d-a711-84b939a1f9b0} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:47786) (comment: 02812_pointwise_array_operations.sql) (in query: DROP DATABASE IF EXISTS test_u4ua85pu ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aac868e 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x00000000286b57c7 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x00000000291f5630 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:361: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000291edc97 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x00000000291ebf11 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x00000000291eb7ed 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b382fc 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1529: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000029b3ed3f 11. ./build_docker/./src/Server/HTTPHandler.cpp:529: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000002d0662d1 12. ./build_docker/./src/Server/HTTPHandler.cpp:705: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000002d06d139 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000002d1cc337 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 18. asan_thread_start(void*) @ 0x000000000aa43059 19. ? @ 0x00007f35aab92ac3 20. ? @ 0x00007f35aac24850 2025.09.09 15:05:21.395187 [ 13328 ] {f6228635-2214-459d-a711-84b939a1f9b0} DynamicQueryHandler: Code: 219. DB::Exception: New table 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aac868e 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x00000000286b57c7 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x00000000291f5630 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:361: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000291edc97 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x00000000291ebf11 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x00000000291eb7ed 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b382fc 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1529: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000029b3ed3f 11. ./build_docker/./src/Server/HTTPHandler.cpp:529: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000002d0662d1 12. ./build_docker/./src/Server/HTTPHandler.cpp:705: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000002d06d139 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000002d1cc337 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 18. asan_thread_start(void*) @ 0x000000000aa43059 19. ? @ 0x00007f35aab92ac3 20. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:05:21.668286 [ 17365 ] {f561daf5-6aec-4317-9bdd-8a7701531fb5} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:47792) (comment: 02812_pointwise_array_operations.sql) (in query: DROP DATABASE IF EXISTS test_u4ua85pu ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aac868e 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x00000000286b57c7 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x00000000291f5630 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:361: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000291edc97 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x00000000291ebf11 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x00000000291eb7ed 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b382fc 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1529: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000029b3ed3f 11. ./build_docker/./src/Server/HTTPHandler.cpp:529: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000002d0662d1 12. ./build_docker/./src/Server/HTTPHandler.cpp:705: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000002d06d139 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000002d1cc337 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 18. asan_thread_start(void*) @ 0x000000000aa43059 19. ? @ 0x00007f35aab92ac3 20. ? @ 0x00007f35aac24850 2025.09.09 15:05:21.687588 [ 17365 ] {f561daf5-6aec-4317-9bdd-8a7701531fb5} DynamicQueryHandler: Code: 219. DB::Exception: New table 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aac868e 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x00000000286b57c7 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x00000000291f5630 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:361: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000291edc97 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x00000000291ebf11 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x00000000291eb7ed 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b382fc 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1529: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000029b3ed3f 11. ./build_docker/./src/Server/HTTPHandler.cpp:529: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000002d0662d1 12. ./build_docker/./src/Server/HTTPHandler.cpp:705: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000002d06d139 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000002d1cc337 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 18. asan_thread_start(void*) @ 0x000000000aa43059 19. ? @ 0x00007f35aab92ac3 20. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:05:21.710823 [ 2993 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:05:21.963786 [ 2977 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:05:22.060687 [ 3612 ] {8fee0159-cf34-4643-a4ee-fbb248030bee} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:47800) (comment: 02812_pointwise_array_operations.sql) (in query: DROP DATABASE IF EXISTS test_u4ua85pu ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aac868e 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x00000000286b57c7 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x00000000291f5630 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:361: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000291edc97 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x00000000291ebf11 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x00000000291eb7ed 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b382fc 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1529: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000029b3ed3f 11. ./build_docker/./src/Server/HTTPHandler.cpp:529: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000002d0662d1 12. ./build_docker/./src/Server/HTTPHandler.cpp:705: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000002d06d139 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000002d1cc337 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 18. asan_thread_start(void*) @ 0x000000000aa43059 19. ? @ 0x00007f35aab92ac3 20. ? @ 0x00007f35aac24850 2025.09.09 15:05:22.072884 [ 3612 ] {8fee0159-cf34-4643-a4ee-fbb248030bee} DynamicQueryHandler: Code: 219. DB::Exception: New table 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aac868e 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x00000000286b57c7 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x00000000291f5630 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:361: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000291edc97 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x00000000291ebf11 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x00000000291eb7ed 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b382fc 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1529: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000029b3ed3f 11. ./build_docker/./src/Server/HTTPHandler.cpp:529: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000002d0662d1 12. ./build_docker/./src/Server/HTTPHandler.cpp:705: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000002d06d139 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000002d1cc337 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 18. asan_thread_start(void*) @ 0x000000000aa43059 19. ? @ 0x00007f35aab92ac3 20. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:05:22.280289 [ 17365 ] {95451438-0cd2-4315-8e2e-4d2e343678dc} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:47808) (comment: 02812_pointwise_array_operations.sql) (in query: DROP DATABASE IF EXISTS test_u4ua85pu ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aac868e 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x00000000286b57c7 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x00000000291f5630 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:361: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000291edc97 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x00000000291ebf11 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x00000000291eb7ed 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b382fc 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1529: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000029b3ed3f 11. ./build_docker/./src/Server/HTTPHandler.cpp:529: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000002d0662d1 12. ./build_docker/./src/Server/HTTPHandler.cpp:705: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000002d06d139 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000002d1cc337 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 18. asan_thread_start(void*) @ 0x000000000aa43059 19. ? @ 0x00007f35aab92ac3 20. ? @ 0x00007f35aac24850 2025.09.09 15:05:22.286640 [ 17365 ] {95451438-0cd2-4315-8e2e-4d2e343678dc} DynamicQueryHandler: Code: 219. DB::Exception: New table 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aac868e 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x00000000286b57c7 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x00000000291f5630 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:361: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000291edc97 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x00000000291ebf11 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x00000000291eb7ed 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b382fc 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1529: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000029b3ed3f 11. ./build_docker/./src/Server/HTTPHandler.cpp:529: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000002d0662d1 12. ./build_docker/./src/Server/HTTPHandler.cpp:705: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000002d06d139 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000002d1cc337 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 18. asan_thread_start(void*) @ 0x000000000aa43059 19. ? @ 0x00007f35aab92ac3 20. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:05:22.458657 [ 3612 ] {04528022-3975-4f6b-9f3a-21fb0e43d44f} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:47820) (comment: 02812_pointwise_array_operations.sql) (in query: DROP DATABASE IF EXISTS test_u4ua85pu ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aac868e 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x00000000286b57c7 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x00000000291f5630 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:361: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000291edc97 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x00000000291ebf11 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x00000000291eb7ed 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b382fc 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1529: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000029b3ed3f 11. ./build_docker/./src/Server/HTTPHandler.cpp:529: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000002d0662d1 12. ./build_docker/./src/Server/HTTPHandler.cpp:705: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000002d06d139 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000002d1cc337 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 18. asan_thread_start(void*) @ 0x000000000aa43059 19. ? @ 0x00007f35aab92ac3 20. ? @ 0x00007f35aac24850 2025.09.09 15:05:22.463535 [ 3612 ] {04528022-3975-4f6b-9f3a-21fb0e43d44f} DynamicQueryHandler: Code: 219. DB::Exception: New table 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aac868e 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x00000000286b57c7 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x00000000291f5630 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:361: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000291edc97 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x00000000291ebf11 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x00000000291eb7ed 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b382fc 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1529: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000029b3ed3f 11. ./build_docker/./src/Server/HTTPHandler.cpp:529: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000002d0662d1 12. ./build_docker/./src/Server/HTTPHandler.cpp:705: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000002d06d139 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000002d1cc337 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 18. asan_thread_start(void*) @ 0x000000000aa43059 19. ? @ 0x00007f35aab92ac3 20. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:05:22.709112 [ 17365 ] {56e840be-d9f6-4f11-92b2-5cd45b8705b0} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:47828) (comment: 02812_pointwise_array_operations.sql) (in query: DROP DATABASE IF EXISTS test_u4ua85pu ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aac868e 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x00000000286b57c7 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x00000000291f5630 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:361: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000291edc97 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x00000000291ebf11 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x00000000291eb7ed 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b382fc 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1529: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000029b3ed3f 11. ./build_docker/./src/Server/HTTPHandler.cpp:529: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000002d0662d1 12. ./build_docker/./src/Server/HTTPHandler.cpp:705: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000002d06d139 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000002d1cc337 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 18. asan_thread_start(void*) @ 0x000000000aa43059 19. ? @ 0x00007f35aab92ac3 20. ? @ 0x00007f35aac24850 2025.09.09 15:05:22.711966 [ 17365 ] {56e840be-d9f6-4f11-92b2-5cd45b8705b0} DynamicQueryHandler: Code: 219. DB::Exception: New table 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aac868e 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x00000000286b57c7 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x00000000291f5630 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:361: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000291edc97 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x00000000291ebf11 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x00000000291eb7ed 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b382fc 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1529: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000029b3ed3f 11. ./build_docker/./src/Server/HTTPHandler.cpp:529: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000002d0662d1 12. ./build_docker/./src/Server/HTTPHandler.cpp:705: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000002d06d139 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000002d1cc337 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 18. asan_thread_start(void*) @ 0x000000000aa43059 19. ? @ 0x00007f35aab92ac3 20. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:05:22.713068 [ 3013 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:05:22.790007 [ 4025 ] {dec09d85-869e-4bcb-981c-8c9e4fde3610} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:47844) (comment: 02812_pointwise_array_operations.sql) (in query: DROP DATABASE IF EXISTS test_u4ua85pu ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aac868e 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x00000000286b57c7 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x00000000291f5630 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:361: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000291edc97 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x00000000291ebf11 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x00000000291eb7ed 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b382fc 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1529: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000029b3ed3f 11. ./build_docker/./src/Server/HTTPHandler.cpp:529: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000002d0662d1 12. ./build_docker/./src/Server/HTTPHandler.cpp:705: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000002d06d139 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000002d1cc337 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 18. asan_thread_start(void*) @ 0x000000000aa43059 19. ? @ 0x00007f35aab92ac3 20. ? @ 0x00007f35aac24850 2025.09.09 15:05:22.798916 [ 4025 ] {dec09d85-869e-4bcb-981c-8c9e4fde3610} DynamicQueryHandler: Code: 219. DB::Exception: New table 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aac868e 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x00000000286b57c7 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x00000000291f5630 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:361: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000291edc97 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x00000000291ebf11 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x00000000291eb7ed 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b382fc 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1529: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000029b3ed3f 11. ./build_docker/./src/Server/HTTPHandler.cpp:529: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000002d0662d1 12. ./build_docker/./src/Server/HTTPHandler.cpp:705: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000002d06d139 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000002d1cc337 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 18. asan_thread_start(void*) @ 0x000000000aa43059 19. ? @ 0x00007f35aab92ac3 20. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:05:22.968687 [ 3023 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:05:23.287058 [ 19252 ] {0dd745c9-5625-41b0-8894-cf2b9017bc39} executeQuery: Code: 394. DB::Exception: Query was cancelled: while executing 'FUNCTION sleep(1_UInt8 :: 0) -> sleep(1_UInt8) UInt8 : 1'. (QUERY_WAS_CANCELLED) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:54214) (comment: 00909_kill_not_initialized_query.sh) (in query: SELECT sum(1) FROM cannot_kill_query WHERE NOT ignore(sleep(1)) SETTINGS max_threads = 1), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aac868e 4. ./build_docker/./src/Interpreters/ProcessList.cpp:480: DB::QueryStatus::checkTimeLimit() @ 0x00000000295fbb84 5. DB::FunctionSleep<(DB::FunctionSleepVariant)0>::execute(std::vector> const&, std::shared_ptr const&, bool) const @ 0x0000000018202475 6. DB::FunctionSleep<(DB::FunctionSleepVariant)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018201711 7. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aac9135 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000cccce5b 9. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccce65c 10. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd2030 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x00000000286fc2bd 12. ./contrib/llvm-project/libcxx/include/vector:547: DB::ExpressionActions::execute(DB::Block&, bool, bool) const @ 0x00000000286ff41d 13. ./build_docker/./src/Storages/VirtualColumnUtils.cpp:102: DB::VirtualColumnUtils::filterBlockWithExpression(std::shared_ptr const&, DB::Block&) @ 0x000000002bdca21e 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::VirtualColumnUtils::filterBlockWithPredicate(DB::ActionsDAG::Node const*, DB::Block&, std::shared_ptr, bool) @ 0x000000002bdda766 15. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:6950: DB::MergeTreeData::getMinMaxCountProjectionBlock(std::shared_ptr const&, std::vector> const&, DB::ActionsDAG const*, std::vector, std::allocator>> const&, std::unordered_map, std::equal_to, std::allocator>> const*, std::shared_ptr) const @ 0x000000002c50a88f 16. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeUseAggregateProjection.cpp:480: DB::QueryPlanOptimizations::getAggregateProjectionCandidates(DB::QueryPlan::Node&, DB::AggregatingStep&, DB::ReadFromMergeTree&, std::shared_ptr, std::equal_to, std::allocator>>> const&, bool) @ 0x000000002dfa3aaa 17. ./src/Processors/QueryPlan/ReadFromMergeTree.h:187: DB::QueryPlanOptimizations::optimizeUseAggregateProjections(DB::QueryPlan::Node&, std::list>&, bool) @ 0x000000002dfa778f 18. ./contrib/llvm-project/libcxx/include/optional:344: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x000000002df631d6 19. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:507: DB::QueryPlan::optimize(DB::QueryPlanOptimizationSettings const&) @ 0x000000002de001ca 20. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:36: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000002ddfec4b 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000002942117f 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x00000000294209e7 23. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b382fc 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 25. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 26. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 30. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 31. asan_thread_start(void*) @ 0x000000000aa43059 2025.09.09 15:05:23.295218 [ 19252 ] {0dd745c9-5625-41b0-8894-cf2b9017bc39} TCPHandler: Code: 394. DB::Exception: Query was cancelled: while executing 'FUNCTION sleep(1_UInt8 :: 0) -> sleep(1_UInt8) UInt8 : 1'. (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aac868e 4. ./build_docker/./src/Interpreters/ProcessList.cpp:480: DB::QueryStatus::checkTimeLimit() @ 0x00000000295fbb84 5. DB::FunctionSleep<(DB::FunctionSleepVariant)0>::execute(std::vector> const&, std::shared_ptr const&, bool) const @ 0x0000000018202475 6. DB::FunctionSleep<(DB::FunctionSleepVariant)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018201711 7. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aac9135 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000cccce5b 9. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccce65c 10. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd2030 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x00000000286fc2bd 12. ./contrib/llvm-project/libcxx/include/vector:547: DB::ExpressionActions::execute(DB::Block&, bool, bool) const @ 0x00000000286ff41d 13. ./build_docker/./src/Storages/VirtualColumnUtils.cpp:102: DB::VirtualColumnUtils::filterBlockWithExpression(std::shared_ptr const&, DB::Block&) @ 0x000000002bdca21e 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::VirtualColumnUtils::filterBlockWithPredicate(DB::ActionsDAG::Node const*, DB::Block&, std::shared_ptr, bool) @ 0x000000002bdda766 15. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:6950: DB::MergeTreeData::getMinMaxCountProjectionBlock(std::shared_ptr const&, std::vector> const&, DB::ActionsDAG const*, std::vector, std::allocator>> const&, std::unordered_map, std::equal_to, std::allocator>> const*, std::shared_ptr) const @ 0x000000002c50a88f 16. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeUseAggregateProjection.cpp:480: DB::QueryPlanOptimizations::getAggregateProjectionCandidates(DB::QueryPlan::Node&, DB::AggregatingStep&, DB::ReadFromMergeTree&, std::shared_ptr, std::equal_to, std::allocator>>> const&, bool) @ 0x000000002dfa3aaa 17. ./src/Processors/QueryPlan/ReadFromMergeTree.h:187: DB::QueryPlanOptimizations::optimizeUseAggregateProjections(DB::QueryPlan::Node&, std::list>&, bool) @ 0x000000002dfa778f 18. ./contrib/llvm-project/libcxx/include/optional:344: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x000000002df631d6 19. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:507: DB::QueryPlan::optimize(DB::QueryPlanOptimizationSettings const&) @ 0x000000002de001ca 20. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:36: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000002ddfec4b 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000002942117f 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x00000000294209e7 23. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b382fc 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 25. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 26. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 30. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 31. asan_thread_start(void*) @ 0x000000000aa43059 2025.09.09 15:05:23.715481 [ 3051 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:05:23.971943 [ 3060 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:05:24.188605 [ 17365 ] {e94acba4-056f-4b5f-93ed-3eb1429533a8} executeQuery: Code: 48. DB::Exception: Function any_respect_nulls does not support RESPECT NULLS. (NOT_IMPLEMENTED) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:54250) (comment: 02941_any_RESPECT_NULL_sparse_column.sql) (in query: SELECT any(value) RESPECT NULLS FROM data_sparse_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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:0: DB::AggregateFunctionFactory::getAssociatedFunctionByNullsAction(String const&, DB::NullsAction) const @ 0x00000000265b57e5 5. ./contrib/llvm-project/libcxx/include/optional:344: DB::AggregateFunctionFactory::tryGetProperties(String, DB::NullsAction) const @ 0x00000000265b31a4 6. ./contrib/llvm-project/libcxx/include/string:1499: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x00000000265b1ad7 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002839a287 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000028367bce 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028366290 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283b62c9 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002835ae03 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000028359104 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000028357f0d 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr, unsigned long) @ 0x000000002921dc0c 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::QueryTreePassManager::runOnlyResolve(std::shared_ptr) @ 0x000000002921d93c 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002941e64c 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&) @ 0x0000000029419aef 18. ./contrib/llvm-project/libcxx/include/vector:432: DB::createLocalPlanForParallelReplicas(std::shared_ptr const&, DB::Block const&, std::shared_ptr, DB::QueryProcessingStage::Enum, std::shared_ptr, std::unique_ptr>, unsigned long) @ 0x000000002ddf7b7e 19. ./build_docker/./src/Interpreters/ClusterProxy/executeQuery.cpp:593: DB::ClusterProxy::executeQueryWithParallelReplicas(DB::QueryPlan&, DB::StorageID const&, DB::Block const&, DB::QueryProcessingStage::Enum, std::shared_ptr const&, std::shared_ptr, std::shared_ptr> const>, std::unique_ptr>) @ 0x000000002aaabeb3 20. ./build_docker/./src/Interpreters/ClusterProxy/executeQuery.cpp:683: DB::ClusterProxy::executeQueryWithParallelReplicas(DB::QueryPlan&, DB::StorageID const&, DB::QueryProcessingStage::Enum, std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr> const>, std::unique_ptr>) @ 0x000000002aaaf188 21. ./build_docker/./src/Planner/PlannerJoinTree.cpp:996: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x000000002946e7d2 22. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1795: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000002945d99d 23. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x000000002942c986 24. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x00000000294261fb 25. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000029421552 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1182: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3737e 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 28. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 29. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 2025.09.09 15:05:24.196056 [ 17365 ] {e94acba4-056f-4b5f-93ed-3eb1429533a8} TCPHandler: Code: 48. DB::Exception: Function any_respect_nulls does not support RESPECT NULLS. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:0: DB::AggregateFunctionFactory::getAssociatedFunctionByNullsAction(String const&, DB::NullsAction) const @ 0x00000000265b57e5 5. ./contrib/llvm-project/libcxx/include/optional:344: DB::AggregateFunctionFactory::tryGetProperties(String, DB::NullsAction) const @ 0x00000000265b31a4 6. ./contrib/llvm-project/libcxx/include/string:1499: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x00000000265b1ad7 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002839a287 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000028367bce 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028366290 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283b62c9 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002835ae03 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000028359104 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000028357f0d 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr, unsigned long) @ 0x000000002921dc0c 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::QueryTreePassManager::runOnlyResolve(std::shared_ptr) @ 0x000000002921d93c 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002941e64c 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&) @ 0x0000000029419aef 18. ./contrib/llvm-project/libcxx/include/vector:432: DB::createLocalPlanForParallelReplicas(std::shared_ptr const&, DB::Block const&, std::shared_ptr, DB::QueryProcessingStage::Enum, std::shared_ptr, std::unique_ptr>, unsigned long) @ 0x000000002ddf7b7e 19. ./build_docker/./src/Interpreters/ClusterProxy/executeQuery.cpp:593: DB::ClusterProxy::executeQueryWithParallelReplicas(DB::QueryPlan&, DB::StorageID const&, DB::Block const&, DB::QueryProcessingStage::Enum, std::shared_ptr const&, std::shared_ptr, std::shared_ptr> const>, std::unique_ptr>) @ 0x000000002aaabeb3 20. ./build_docker/./src/Interpreters/ClusterProxy/executeQuery.cpp:683: DB::ClusterProxy::executeQueryWithParallelReplicas(DB::QueryPlan&, DB::StorageID const&, DB::QueryProcessingStage::Enum, std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr> const>, std::unique_ptr>) @ 0x000000002aaaf188 21. ./build_docker/./src/Planner/PlannerJoinTree.cpp:996: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x000000002946e7d2 22. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1795: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000002945d99d 23. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x000000002942c986 24. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x00000000294261fb 25. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000029421552 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1182: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3737e 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 28. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 29. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 2025.09.09 15:05:24.718782 [ 3072 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:05:24.975208 [ 3077 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:05:25.721015 [ 3095 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:05:25.978235 [ 3103 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:05:26.165461 [ 4025 ] {b6662797-f242-4c1f-9b61-6ce417bca9ac} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=773, jobs=735). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:54292) (comment: 00909_kill_not_initialized_query.sh) (in query: SELECT count() FROM system.processes where query='SELECT count() FROM cannot_kill_query WHERE NOT ignore(sleep(1)) SETTINGS max_threads = 1, 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af872f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af7b2d1 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af7c3f3 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d36920d 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000002d369e5f 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processOrdinaryQuery() @ 0x000000002d18af7b 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d17644a 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 15. asan_thread_start(void*) @ 0x000000000aa43059 16. ? @ 0x00007f35aab92ac3 17. ? @ 0x00007f35aac24850 2025.09.09 15:05:26.177567 [ 4025 ] {b6662797-f242-4c1f-9b61-6ce417bca9ac} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=773, 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af872f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af7b2d1 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af7c3f3 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d36920d 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000002d369e5f 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processOrdinaryQuery() @ 0x000000002d18af7b 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d17644a 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 15. asan_thread_start(void*) @ 0x000000000aa43059 16. ? @ 0x00007f35aab92ac3 17. ? @ 0x00007f35aac24850 2025.09.09 15:05:26.727439 [ 3087 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:05:26.982612 [ 3127 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:05:27.731576 [ 3139 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:05:27.985688 [ 3161 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:05:28.393257 [ 19252 ] {ff131d88-a91c-485e-8e67-241d49201553} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=13, jobs=1): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:54320) (comment: 01047_no_alias_columns_with_table_aliases.sql) (in query: select * from requests where event_date > '2000-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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af80b71 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80746 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002c765aab 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:1197: ? @ 0x000000002c7602b8 8. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x000000002c75fc2b 9. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:0: DB::MergeTreeReaderWide::addStream(DB::ISerialization::SubstreamPath const&, String const&) @ 0x000000002c802c31 10. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:0: void std::__function::__policy_invoker::__call_impl const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x000000002c804a95 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000027a9e455 12. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:106: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x0000000027a9ea65 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:100: DB::MergeTreeReaderWide::addStreams(DB::NameAndTypePair const&, std::shared_ptr const&) @ 0x000000002c7fe815 14. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:0: DB::MergeTreeReaderWide::MergeTreeReaderWide(std::shared_ptr, DB::NamesAndTypesList, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*, DB::MarkCache*, DB::MarkRanges, DB::MergeTreeReaderSettings, std::map, std::allocator>>, std::function const&, int) @ 0x000000002c7fdeea 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) @ 0x000000002c5eb9c6 16. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWide.cpp:43: DB::MergeTreeDataPartWide::getReader(DB::NamesAndTypesList const&, std::shared_ptr const&, DB::MarkRanges const&, std::unordered_map, std::equal_to, std::allocator>> const&, DB::UncompressedCache*, DB::MarkCache*, std::shared_ptr const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) const @ 0x000000002c5e354e 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:44: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x000000002c82acda 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:295: DB::MergeTreeReadPoolBase::createTask(std::shared_ptr, DB::MarkRanges, DB::MergeTreeReadTask*) const @ 0x000000002de9c234 19. ./build_docker/./src/Storages/MergeTree/MergeTreeReadPoolInOrder.cpp:72: DB::MergeTreeReadPoolInOrder::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x000000002deff671 20. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectAlgorithms.cpp:17: DB::MergeTreeInOrderSelectAlgorithm::getNewTask(DB::IMergeTreeReadPool&, DB::MergeTreeReadTask*) @ 0x000000002dea3919 21. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:0: DB::MergeTreeSelectProcessor::read() @ 0x000000002c8241d2 22. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000002de6d77a 23. ./build_docker/./src/Processors/ISource.cpp:0: DB::ISource::work() @ 0x000000002d3290a1 24. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000002d34877c 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000002d34827b 28. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002d36bcf7 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 31. asan_thread_start(void*) @ 0x000000000aa43059 2025.09.09 15:05:28.416424 [ 19252 ] {ff131d88-a91c-485e-8e67-241d49201553} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=13, jobs=1): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af80b71 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80746 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002c765aab 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:1197: ? @ 0x000000002c7602b8 8. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x000000002c75fc2b 9. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:0: DB::MergeTreeReaderWide::addStream(DB::ISerialization::SubstreamPath const&, String const&) @ 0x000000002c802c31 10. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:0: void std::__function::__policy_invoker::__call_impl const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x000000002c804a95 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000027a9e455 12. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:106: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x0000000027a9ea65 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:100: DB::MergeTreeReaderWide::addStreams(DB::NameAndTypePair const&, std::shared_ptr const&) @ 0x000000002c7fe815 14. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:0: DB::MergeTreeReaderWide::MergeTreeReaderWide(std::shared_ptr, DB::NamesAndTypesList, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*, DB::MarkCache*, DB::MarkRanges, DB::MergeTreeReaderSettings, std::map, std::allocator>>, std::function const&, int) @ 0x000000002c7fdeea 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) @ 0x000000002c5eb9c6 16. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWide.cpp:43: DB::MergeTreeDataPartWide::getReader(DB::NamesAndTypesList const&, std::shared_ptr const&, DB::MarkRanges const&, std::unordered_map, std::equal_to, std::allocator>> const&, DB::UncompressedCache*, DB::MarkCache*, std::shared_ptr const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) const @ 0x000000002c5e354e 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:44: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x000000002c82acda 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:295: DB::MergeTreeReadPoolBase::createTask(std::shared_ptr, DB::MarkRanges, DB::MergeTreeReadTask*) const @ 0x000000002de9c234 19. ./build_docker/./src/Storages/MergeTree/MergeTreeReadPoolInOrder.cpp:72: DB::MergeTreeReadPoolInOrder::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x000000002deff671 20. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectAlgorithms.cpp:17: DB::MergeTreeInOrderSelectAlgorithm::getNewTask(DB::IMergeTreeReadPool&, DB::MergeTreeReadTask*) @ 0x000000002dea3919 21. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:0: DB::MergeTreeSelectProcessor::read() @ 0x000000002c8241d2 22. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000002de6d77a 23. ./build_docker/./src/Processors/ISource.cpp:0: DB::ISource::work() @ 0x000000002d3290a1 24. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000002d34877c 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000002d34827b 28. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002d36bcf7 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 31. asan_thread_start(void*) @ 0x000000000aa43059 2025.09.09 15:05:28.733923 [ 3159 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:05:28.989592 [ 3183 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:05:29.744069 [ 3196 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:05:29.991415 [ 3209 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:05:30.746578 [ 3231 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:05:30.993916 [ 2750 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:05:31.748617 [ 2757 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:05:31.997719 [ 2739 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:05:32.761037 [ 2797 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:05:32.954840 [ 4025 ] {65e322d0-8218-4dd8-88d2-1d6f8e996d8f} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=2, jobs=2). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:44658) (comment: 00457_log_tinylog_stripelog_nullable.sql) (in query: SELECT ns FROM nullable_00457 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af80b71 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80746 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d34b5ca 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000002d3486e4 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000002d34827b 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002d36bcf7 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 12. asan_thread_start(void*) @ 0x000000000aa43059 13. ? @ 0x00007f35aab92ac3 14. ? @ 0x00007f35aac24850 2025.09.09 15:05:32.978941 [ 4025 ] {65e322d0-8218-4dd8-88d2-1d6f8e996d8f} 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af80b71 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80746 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d34b5ca 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000002d3486e4 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000002d34827b 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002d36bcf7 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 12. asan_thread_start(void*) @ 0x000000000aa43059 13. ? @ 0x00007f35aab92ac3 14. ? @ 0x00007f35aac24850 2025.09.09 15:05:33.000865 [ 2798 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:05:33.766475 [ 2841 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:05:34.007778 [ 2849 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:05:34.773352 [ 2876 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:05:35.016838 [ 2884 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:05:35.776085 [ 2932 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:05:36.019320 [ 2949 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:05:36.779310 [ 3030 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:05:37.021176 [ 3045 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:05:37.781743 [ 3130 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:05:38.023246 [ 3163 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:05:38.783825 [ 2745 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:05:39.025127 [ 2769 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:05:39.504285 [ 19252 ] {d7350f55-1ef5-4aac-ab3b-4c055aa89d5a} 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.10505.altinitytest (altinity build)) (from [::1]:44688) (comment: 00814_replicated_minimalistic_part_header_zookeeper.sh) (in query: SELECT _part, x FROM part_header_r1 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af819ed 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80746 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d34b5ca 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000002d3486e4 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000002d34827b 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002d36bcf7 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 12. asan_thread_start(void*) @ 0x000000000aa43059 13. ? @ 0x00007f35aab92ac3 14. ? @ 0x00007f35aac24850 2025.09.09 15:05:39.508348 [ 19252 ] {d7350f55-1ef5-4aac-ab3b-4c055aa89d5a} 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af819ed 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80746 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d34b5ca 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000002d3486e4 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000002d34827b 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002d36bcf7 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 12. asan_thread_start(void*) @ 0x000000000aa43059 13. ? @ 0x00007f35aab92ac3 14. ? @ 0x00007f35aac24850 2025.09.09 15:05:39.786109 [ 2863 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:05:40.027700 [ 2887 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:05:40.788412 [ 2959 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:05:41.030499 [ 2967 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:05:41.791464 [ 3058 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:05:42.041267 [ 3093 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:05:42.793843 [ 3198 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:05:43.043381 [ 3219 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:05:43.795801 [ 2784 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:05:44.045951 [ 2813 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:05:44.798388 [ 2884 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:05:45.048423 [ 2890 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:05:45.800550 [ 3006 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:05:45.877783 [ 13328 ] {} DynamicQueryHandler: Code: 452. DB::Exception: Setting max_execution_time shouldn't be greater than 60. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x0000000026f841fa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:368: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f81de0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__algorithm/find_if.h:25: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f808a4 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000002d065739 10. ./build_docker/./src/Server/HTTPHandler.cpp:705: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000002d06d139 11. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000002d1cc337 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 15. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 16. asan_thread_start(void*) @ 0x000000000aa43059 17. ? @ 0x00007f35aab92ac3 18. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:05:46.051044 [ 3052 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:05:46.331983 [ 3612 ] {95c35d64-f8b1-43ba-979c-b566d2c42bab} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=9, jobs=0): (while reading column quantity): (while reading from part /var/lib/clickhouse/store/2cb/2cb4ce06-48da-4960-9214-b419b18fd820/202001_1_1_0/ in table test_3.stack (2cb4ce06-48da-4960-9214-b419b18fd820) located on disk default of type local, from mark 96 with max_rows_to_read = 24576): While executing MergeTreeSelect(pool: ReadPoolParallelReplicas, algorithm: Thread). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:34754) (comment: 01592_long_window_functions1.sql) (in query: SELECT `__table1`.`brand_id` AS `brand_id`, `__table1`.`rack_id` AS `rack_id`, `__table1`.`quantity` AS `quantity`, row_number() OVER (PARTITION BY `__table1`.`brand_id`, `__table1`.`rack_id` ORDER BY `__table1`.`quantity` ASC) AS `rn` FROM `test_3`.`stack` AS `__table1`), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af80b71 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80746 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000266005a2 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000265fffb4 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:1197: ? @ 0x00000000265fd4e7 9. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:62: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x00000000265e6fbd 10. ./contrib/llvm-project/libcxx/include/future:1123: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x00000000265e7bb3 11. DB::ReadBuffer::next() @ 0x000000000b528aeb 12. DB::ReadBuffer::readStrict(char*, unsigned long) @ 0x000000000b581216 13. ./build_docker/./src/Compression/CompressedReadBufferBase.cpp:0: DB::CompressedReadBufferBase::readCompressedData(unsigned long&, unsigned long&, bool) @ 0x000000002775f390 14. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:122: DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x0000000027764cac 15. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:222: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x0000000027b97730 16. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:0: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x0000000027aa00db 17. ./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) @ 0x000000002c80211e 18. ./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>>&) @ 0x000000002c800e8d 19. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:118: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7c9d8a 20. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x000000002c7e0473 21. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x000000002c7dbec3 22. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:0: DB::MergeTreeReadTask::read(DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002c82d05b 23. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:38: DB::MergeTreeThreadSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&, DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002de66094 24. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:0: DB::MergeTreeSelectProcessor::read() @ 0x000000002c8242f9 25. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000002de6d77a 26. ./build_docker/./src/Processors/ISource.cpp:0: DB::ISource::work() @ 0x000000002d3290a1 27. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 28. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 29. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:381: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000002d34bd35 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7eaf0 31. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001af8a79f 2025.09.09 15:05:46.372929 [ 3612 ] {95c35d64-f8b1-43ba-979c-b566d2c42bab} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=9, jobs=0): (while reading column quantity): (while reading from part /var/lib/clickhouse/store/2cb/2cb4ce06-48da-4960-9214-b419b18fd820/202001_1_1_0/ in table test_3.stack (2cb4ce06-48da-4960-9214-b419b18fd820) located on disk default of type local, from mark 96 with max_rows_to_read = 24576): While executing MergeTreeSelect(pool: ReadPoolParallelReplicas, algorithm: Thread). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af80b71 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80746 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000266005a2 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000265fffb4 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:1197: ? @ 0x00000000265fd4e7 9. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:62: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x00000000265e6fbd 10. ./contrib/llvm-project/libcxx/include/future:1123: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x00000000265e7bb3 11. DB::ReadBuffer::next() @ 0x000000000b528aeb 12. DB::ReadBuffer::readStrict(char*, unsigned long) @ 0x000000000b581216 13. ./build_docker/./src/Compression/CompressedReadBufferBase.cpp:0: DB::CompressedReadBufferBase::readCompressedData(unsigned long&, unsigned long&, bool) @ 0x000000002775f390 14. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:122: DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x0000000027764cac 15. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:222: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x0000000027b97730 16. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:0: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x0000000027aa00db 17. ./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) @ 0x000000002c80211e 18. ./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>>&) @ 0x000000002c800e8d 19. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:118: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7c9d8a 20. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x000000002c7e0473 21. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x000000002c7dbec3 22. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:0: DB::MergeTreeReadTask::read(DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002c82d05b 23. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:38: DB::MergeTreeThreadSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&, DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002de66094 24. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:0: DB::MergeTreeSelectProcessor::read() @ 0x000000002c8242f9 25. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000002de6d77a 26. ./build_docker/./src/Processors/ISource.cpp:0: DB::ISource::work() @ 0x000000002d3290a1 27. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 28. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 29. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:381: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000002d34bd35 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7eaf0 31. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001af8a79f 2025.09.09 15:05:46.628749 [ 19252 ] {97124728-094e-4412-ac76-26a2ab98a13e} executeQuery: Code: 439. DB::Exception: Received from 127.0.0.9:9000. DB::Exception: Cannot schedule a task: fault injected (threads=9, jobs=0): (while reading column quantity): (while reading from part /var/lib/clickhouse/store/2cb/2cb4ce06-48da-4960-9214-b419b18fd820/202001_1_1_0/ in table test_3.stack (2cb4ce06-48da-4960-9214-b419b18fd820) located on disk default of type local, from mark 96 with max_rows_to_read = 24576): While executing MergeTreeSelect(pool: ReadPoolParallelReplicas, algorithm: Thread). Stack trace: 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af80b71 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80746 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000266005a2 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000265fffb4 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:1197: ? @ 0x00000000265fd4e7 9. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:62: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x00000000265e6fbd 10. ./contrib/llvm-project/libcxx/include/future:1123: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x00000000265e7bb3 11. DB::ReadBuffer::next() @ 0x000000000b528aeb 12. DB::ReadBuffer::readStrict(char*, unsigned long) @ 0x000000000b581216 13. ./build_docker/./src/Compression/CompressedReadBufferBase.cpp:0: DB::CompressedReadBufferBase::readCompressedData(unsigned long&, unsigned long&, bool) @ 0x000000002775f390 14. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:122: DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x0000000027764cac 15. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:222: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x0000000027b97730 16. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:0: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x0000000027aa00db 17. ./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) @ 0x000000002c80211e 18. ./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>>&) @ 0x000000002c800e8d 19. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:118: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7c9d8a 20. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x000000002c7e0473 21. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x000000002c7dbec3 22. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:0: DB::MergeTreeReadTask::read(DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002c82d05b 23. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:38: DB::MergeTreeThreadSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&, DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002de66094 24. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:0: DB::MergeTreeSelectProcessor::read() @ 0x000000002c8242f9 25. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000002de6d77a 26. ./build_docker/./src/Processors/ISource.cpp:0: DB::ISource::work() @ 0x000000002d3290a1 27. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 28. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 29. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:381: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000002d34bd35 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7eaf0 31. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001af8a79f : While executing Remote. (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:40866) (comment: 01592_long_window_functions1.sql) (in query: select cityHash64( toString( groupArray (tuple(*) ) )) from ( select brand_id, rack_id, quantity from ( select brand_id, rack_id, quantity, row_number() over (partition by brand_id, rack_id order by quantity) rn from stack ) as t0 where rn <= 2 order by brand_id, rack_id, quantity ) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. ./contrib/llvm-project/libcxx/include/string:1499: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x000000001aeb974e 3. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::Connection::receiveException() const @ 0x000000002cee6c6a 4. ./build_docker/./src/Client/Connection.cpp:0: DB::Connection::receivePacket() @ 0x000000002cef780e 5. ./build_docker/./src/Client/MultiplexedConnections.cpp:340: DB::MultiplexedConnections::receivePacketUnlocked(std::function) @ 0x000000002cf8e09e 6. ./build_docker/./src/QueryPipeline/RemoteQueryExecutorReadContext.cpp:0: DB::RemoteQueryExecutorReadContext::Task::run(std::function, std::function) @ 0x00000000278ad616 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000278ab436 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000278aaa44 9. ./contrib/boost/boost/context/fiber_ucontext.hpp:82: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x00000000278a8394 2025.09.09 15:05:46.665360 [ 19252 ] {97124728-094e-4412-ac76-26a2ab98a13e} TCPHandler: Code: 439. DB::Exception: Received from 127.0.0.9:9000. DB::Exception: Cannot schedule a task: fault injected (threads=9, jobs=0): (while reading column quantity): (while reading from part /var/lib/clickhouse/store/2cb/2cb4ce06-48da-4960-9214-b419b18fd820/202001_1_1_0/ in table test_3.stack (2cb4ce06-48da-4960-9214-b419b18fd820) located on disk default of type local, from mark 96 with max_rows_to_read = 24576): While executing MergeTreeSelect(pool: ReadPoolParallelReplicas, algorithm: Thread). Stack trace: 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af80b71 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80746 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000266005a2 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000265fffb4 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:1197: ? @ 0x00000000265fd4e7 9. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:62: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x00000000265e6fbd 10. ./contrib/llvm-project/libcxx/include/future:1123: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x00000000265e7bb3 11. DB::ReadBuffer::next() @ 0x000000000b528aeb 12. DB::ReadBuffer::readStrict(char*, unsigned long) @ 0x000000000b581216 13. ./build_docker/./src/Compression/CompressedReadBufferBase.cpp:0: DB::CompressedReadBufferBase::readCompressedData(unsigned long&, unsigned long&, bool) @ 0x000000002775f390 14. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:122: DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x0000000027764cac 15. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:222: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x0000000027b97730 16. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:0: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x0000000027aa00db 17. ./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) @ 0x000000002c80211e 18. ./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>>&) @ 0x000000002c800e8d 19. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:118: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7c9d8a 20. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x000000002c7e0473 21. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x000000002c7dbec3 22. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:0: DB::MergeTreeReadTask::read(DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002c82d05b 23. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:38: DB::MergeTreeThreadSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&, DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002de66094 24. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:0: DB::MergeTreeSelectProcessor::read() @ 0x000000002c8242f9 25. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000002de6d77a 26. ./build_docker/./src/Processors/ISource.cpp:0: DB::ISource::work() @ 0x000000002d3290a1 27. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 28. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 29. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:381: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000002d34bd35 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7eaf0 31. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001af8a79f : 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. ./contrib/llvm-project/libcxx/include/string:1499: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x000000001aeb974e 3. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::Connection::receiveException() const @ 0x000000002cee6c6a 4. ./build_docker/./src/Client/Connection.cpp:0: DB::Connection::receivePacket() @ 0x000000002cef780e 5. ./build_docker/./src/Client/MultiplexedConnections.cpp:340: DB::MultiplexedConnections::receivePacketUnlocked(std::function) @ 0x000000002cf8e09e 6. ./build_docker/./src/QueryPipeline/RemoteQueryExecutorReadContext.cpp:0: DB::RemoteQueryExecutorReadContext::Task::run(std::function, std::function) @ 0x00000000278ad616 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000278ab436 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000278aaa44 9. ./contrib/boost/boost/context/fiber_ucontext.hpp:82: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x00000000278a8394 2025.09.09 15:05:46.809028 [ 3114 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:05:47.058985 [ 3137 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:05:47.811287 [ 3212 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:05:48.061173 [ 2750 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:05:48.813336 [ 2798 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:05:49.063346 [ 2815 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:05:49.815420 [ 2912 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:05:50.065365 [ 2913 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:05:50.817802 [ 3024 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:05:51.067366 [ 3045 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:05:51.820407 [ 3123 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:05:52.069197 [ 3150 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:05:52.822538 [ 3214 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:05:53.070788 [ 2757 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:05:53.824131 [ 2836 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:05:54.072444 [ 2860 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:05:54.826082 [ 2961 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:05:55.074443 [ 2981 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:05:55.828285 [ 3072 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:05:56.076290 [ 3097 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:05:56.831064 [ 3191 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:05:57.078118 [ 3219 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:05:57.832971 [ 2800 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:05:58.079846 [ 2807 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:05:58.842719 [ 2903 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:05:59.081483 [ 2943 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:05:59.845815 [ 3005 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:06:00.083887 [ 3029 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:06:00.848329 [ 3123 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:06:01.085837 [ 3137 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:06:01.851623 [ 3232 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:06:02.088483 [ 2734 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:06:02.873375 [ 2823 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:06:03.090716 [ 2837 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:06:03.875460 [ 2940 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:06:04.095838 [ 2980 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:06:04.231997 [ 2688 ] {481500a6-228f-40a2-bcd4-5f33692c2940} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=9, jobs=0): (while reading column id2): (while reading from part /var/lib/clickhouse/store/acf/acf68a41-ece8-493c-b6ee-ab8e564c28cb/all_1_1_0/ in table test_3.t (acf68a41-ece8-493c-b6ee-ab8e564c28cb) located on disk default of type local, from mark 359 with max_rows_to_read = 10000): While executing MergeTreeSelect(pool: ReadPoolParallelReplicas, algorithm: Thread). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:57548) (comment: 01710_query_log_with_projection_info.sql) (in query: SELECT sum(`__table1`.`id3`) AS `sum(id3)` FROM `test_3`.`t` AS `__table1` GROUP BY `__table1`.`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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af80b71 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80746 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000266005a2 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000265fffb4 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:1197: ? @ 0x00000000265fd4e7 9. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:62: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x00000000265e6fbd 10. ./contrib/llvm-project/libcxx/include/future:1123: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x00000000265e7bb3 11. DB::ReadBuffer::next() @ 0x000000000b528aeb 12. ./src/IO/ReadBuffer.h:0: DB::CompressedReadBufferBase::readCompressedData(unsigned long&, unsigned long&, bool) @ 0x000000002775f11b 13. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:22: DB::CompressedReadBufferFromFile::nextImpl() @ 0x0000000027763d41 14. DB::ReadBuffer::next() @ 0x000000000b528aeb 15. ./build_docker/./src/DataTypes/Serializations/SerializationSparse.cpp:85: DB::SerializationSparse::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x0000000027c0ae72 16. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:0: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x000000002c7b254b 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7eb79e 18. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:118: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7c9d8a 19. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x000000002c7e0473 20. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x000000002c7dbec3 21. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:0: DB::MergeTreeReadTask::read(DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002c82d05b 22. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:38: DB::MergeTreeThreadSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&, DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002de66094 23. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:0: DB::MergeTreeSelectProcessor::read() @ 0x000000002c8242f9 24. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000002de6d77a 25. ./build_docker/./src/Processors/ISource.cpp:0: DB::ISource::work() @ 0x000000002d3290a1 26. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 27. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 28. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:381: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000002d34bd35 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7eaf0 30. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001af8a79f 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 2025.09.09 15:06:04.235549 [ 2688 ] {481500a6-228f-40a2-bcd4-5f33692c2940} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=9, jobs=0): (while reading column id2): (while reading from part /var/lib/clickhouse/store/acf/acf68a41-ece8-493c-b6ee-ab8e564c28cb/all_1_1_0/ in table test_3.t (acf68a41-ece8-493c-b6ee-ab8e564c28cb) located on disk default of type local, from mark 359 with max_rows_to_read = 10000): While executing MergeTreeSelect(pool: ReadPoolParallelReplicas, algorithm: Thread). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af80b71 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80746 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000266005a2 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000265fffb4 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:1197: ? @ 0x00000000265fd4e7 9. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:62: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x00000000265e6fbd 10. ./contrib/llvm-project/libcxx/include/future:1123: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x00000000265e7bb3 11. DB::ReadBuffer::next() @ 0x000000000b528aeb 12. ./src/IO/ReadBuffer.h:0: DB::CompressedReadBufferBase::readCompressedData(unsigned long&, unsigned long&, bool) @ 0x000000002775f11b 13. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:22: DB::CompressedReadBufferFromFile::nextImpl() @ 0x0000000027763d41 14. DB::ReadBuffer::next() @ 0x000000000b528aeb 15. ./build_docker/./src/DataTypes/Serializations/SerializationSparse.cpp:85: DB::SerializationSparse::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x0000000027c0ae72 16. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:0: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x000000002c7b254b 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7eb79e 18. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:118: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7c9d8a 19. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x000000002c7e0473 20. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x000000002c7dbec3 21. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:0: DB::MergeTreeReadTask::read(DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002c82d05b 22. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:38: DB::MergeTreeThreadSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&, DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002de66094 23. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:0: DB::MergeTreeSelectProcessor::read() @ 0x000000002c8242f9 24. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000002de6d77a 25. ./build_docker/./src/Processors/ISource.cpp:0: DB::ISource::work() @ 0x000000002d3290a1 26. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 27. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 28. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:381: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000002d34bd35 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7eaf0 30. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001af8a79f 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 2025.09.09 15:06:04.244924 [ 19252 ] {25e0829c-a1f8-4f10-9936-bb12feecad7f} executeQuery: Code: 439. DB::Exception: Received from 127.0.0.10:9000. DB::Exception: Cannot schedule a task: fault injected (threads=9, jobs=0): (while reading column id2): (while reading from part /var/lib/clickhouse/store/acf/acf68a41-ece8-493c-b6ee-ab8e564c28cb/all_1_1_0/ in table test_3.t (acf68a41-ece8-493c-b6ee-ab8e564c28cb) located on disk default of type local, from mark 359 with max_rows_to_read = 10000): While executing MergeTreeSelect(pool: ReadPoolParallelReplicas, algorithm: Thread). Stack trace: 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af80b71 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80746 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000266005a2 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000265fffb4 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:1197: ? @ 0x00000000265fd4e7 9. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:62: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x00000000265e6fbd 10. ./contrib/llvm-project/libcxx/include/future:1123: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x00000000265e7bb3 11. DB::ReadBuffer::next() @ 0x000000000b528aeb 12. ./src/IO/ReadBuffer.h:0: DB::CompressedReadBufferBase::readCompressedData(unsigned long&, unsigned long&, bool) @ 0x000000002775f11b 13. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:22: DB::CompressedReadBufferFromFile::nextImpl() @ 0x0000000027763d41 14. DB::ReadBuffer::next() @ 0x000000000b528aeb 15. ./build_docker/./src/DataTypes/Serializations/SerializationSparse.cpp:85: DB::SerializationSparse::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x0000000027c0ae72 16. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:0: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x000000002c7b254b 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7eb79e 18. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:118: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7c9d8a 19. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x000000002c7e0473 20. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x000000002c7dbec3 21. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:0: DB::MergeTreeReadTask::read(DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002c82d05b 22. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:38: DB::MergeTreeThreadSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&, DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002de66094 23. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:0: DB::MergeTreeSelectProcessor::read() @ 0x000000002c8242f9 24. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000002de6d77a 25. ./build_docker/./src/Processors/ISource.cpp:0: DB::ISource::work() @ 0x000000002d3290a1 26. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 27. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 28. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:381: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000002d34bd35 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7eaf0 30. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001af8a79f 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 : While executing Remote. (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:58746) (comment: 01710_query_log_with_projection_info.sql) (in query: SELECT sum(id3) FROM t GROUP BY id2 FORMAT Null;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. ./contrib/llvm-project/libcxx/include/string:1499: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x000000001aeb974e 3. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::Connection::receiveException() const @ 0x000000002cee6c6a 4. ./build_docker/./src/Client/Connection.cpp:0: DB::Connection::receivePacket() @ 0x000000002cef780e 5. ./build_docker/./src/Client/MultiplexedConnections.cpp:340: DB::MultiplexedConnections::receivePacketUnlocked(std::function) @ 0x000000002cf8e09e 6. ./build_docker/./src/QueryPipeline/RemoteQueryExecutorReadContext.cpp:0: DB::RemoteQueryExecutorReadContext::Task::run(std::function, std::function) @ 0x00000000278ad616 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000278ab436 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000278aaa44 9. ./contrib/boost/boost/context/fiber_ucontext.hpp:82: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x00000000278a8394 2025.09.09 15:06:04.248789 [ 19252 ] {25e0829c-a1f8-4f10-9936-bb12feecad7f} TCPHandler: Code: 439. DB::Exception: Received from 127.0.0.10:9000. DB::Exception: Cannot schedule a task: fault injected (threads=9, jobs=0): (while reading column id2): (while reading from part /var/lib/clickhouse/store/acf/acf68a41-ece8-493c-b6ee-ab8e564c28cb/all_1_1_0/ in table test_3.t (acf68a41-ece8-493c-b6ee-ab8e564c28cb) located on disk default of type local, from mark 359 with max_rows_to_read = 10000): While executing MergeTreeSelect(pool: ReadPoolParallelReplicas, algorithm: Thread). Stack trace: 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af80b71 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80746 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000266005a2 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000265fffb4 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:1197: ? @ 0x00000000265fd4e7 9. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:62: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x00000000265e6fbd 10. ./contrib/llvm-project/libcxx/include/future:1123: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x00000000265e7bb3 11. DB::ReadBuffer::next() @ 0x000000000b528aeb 12. ./src/IO/ReadBuffer.h:0: DB::CompressedReadBufferBase::readCompressedData(unsigned long&, unsigned long&, bool) @ 0x000000002775f11b 13. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:22: DB::CompressedReadBufferFromFile::nextImpl() @ 0x0000000027763d41 14. DB::ReadBuffer::next() @ 0x000000000b528aeb 15. ./build_docker/./src/DataTypes/Serializations/SerializationSparse.cpp:85: DB::SerializationSparse::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x0000000027c0ae72 16. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:0: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x000000002c7b254b 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7eb79e 18. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:118: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7c9d8a 19. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x000000002c7e0473 20. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x000000002c7dbec3 21. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:0: DB::MergeTreeReadTask::read(DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002c82d05b 22. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:38: DB::MergeTreeThreadSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&, DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002de66094 23. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:0: DB::MergeTreeSelectProcessor::read() @ 0x000000002c8242f9 24. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000002de6d77a 25. ./build_docker/./src/Processors/ISource.cpp:0: DB::ISource::work() @ 0x000000002d3290a1 26. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 27. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 28. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:381: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000002d34bd35 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7eaf0 30. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001af8a79f 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 : 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. ./contrib/llvm-project/libcxx/include/string:1499: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x000000001aeb974e 3. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::Connection::receiveException() const @ 0x000000002cee6c6a 4. ./build_docker/./src/Client/Connection.cpp:0: DB::Connection::receivePacket() @ 0x000000002cef780e 5. ./build_docker/./src/Client/MultiplexedConnections.cpp:340: DB::MultiplexedConnections::receivePacketUnlocked(std::function) @ 0x000000002cf8e09e 6. ./build_docker/./src/QueryPipeline/RemoteQueryExecutorReadContext.cpp:0: DB::RemoteQueryExecutorReadContext::Task::run(std::function, std::function) @ 0x00000000278ad616 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000278ab436 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000278aaa44 9. ./contrib/boost/boost/context/fiber_ucontext.hpp:82: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x00000000278a8394 2025.09.09 15:06:04.877740 [ 3028 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:06:05.013727 [ 19252 ] {fc7fd888-3eca-4d2f-b68e-74285f2e770b} executeQuery: Code: 452. DB::Exception: Setting allow_experimental_object_type should not be changed. (SETTING_CONSTRAINT_VIOLATION) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:58762) (comment: 01825_type_json_describe.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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x0000000026f807e3 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x000000002853b6ad 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterSetQuery::execute() @ 0x00000000294f603b 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b382fc 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 15:06:05.017551 [ 19252 ] {fc7fd888-3eca-4d2f-b68e-74285f2e770b} 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x0000000026f807e3 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x000000002853b6ad 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterSetQuery::execute() @ 0x00000000294f603b 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b382fc 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 15:06:05.098143 [ 3076 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:06:05.880178 [ 3141 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:06:06.100231 [ 3175 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:06:06.882976 [ 2753 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:06:07.102794 [ 2758 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:06:07.885247 [ 2822 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:06:08.104903 [ 2869 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:06:08.887401 [ 2930 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:06:09.107855 [ 2963 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:06:09.889509 [ 3087 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:06:10.110282 [ 3152 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:06:10.891320 [ 2792 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:06:11.195943 [ 2831 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:06:11.894407 [ 2912 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:06:12.225725 [ 2923 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:06:12.914883 [ 3037 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:06:13.228084 [ 3041 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:06:13.917530 [ 3143 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:06:14.128479 [ 3339 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {1e64423d-b43b-45ea-b85e-a97c07ea6431::202509_1_122_24}: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=13, jobs=0). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af80b71 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80746 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002c765aab 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:1197: ? @ 0x000000002c7602b8 8. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x000000002c75fc2b 9. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:0: DB::MergeTreeReaderCompact::MergeTreeReaderCompact(std::shared_ptr, DB::NamesAndTypesList, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*, DB::MarkCache*, DB::MarkRanges, DB::MergeTreeReaderSettings, std::map, std::allocator>>, std::function const&, int) @ 0x000000002c7aee03 10. ./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.h:16: DB::MergeTreeReaderCompactSingleBuffer::MergeTreeReaderCompactSingleBuffer&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int&&) @ 0x000000002c5d6d21 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::MergeTreeDataPartCompact::getReader(DB::NamesAndTypesList const&, std::shared_ptr const&, DB::MarkRanges const&, std::unordered_map, std::equal_to, std::allocator>> const&, DB::UncompressedCache*, DB::MarkCache*, std::shared_ptr const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) const @ 0x000000002c5d1037 12. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:169: DB::MergeTreeSequentialSource::MergeTreeSequentialSource(DB::MergeTreeSequentialSourceType, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::vector>, std::optional, bool, bool, bool) @ 0x000000002c80c330 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:35: DB::MergeTreeSequentialSource* std::construct_at[abi:v15007] const&, std::shared_ptr&, std::shared_ptr&, std::vector>&, std::optional, bool, bool&, bool&, DB::MergeTreeSequentialSource*>(DB::MergeTreeSequentialSource*, DB::MergeTreeSequentialSourceType&, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr&, std::shared_ptr&, std::vector>&, std::optional&&, bool&&, bool&, bool&) @ 0x000000002c81320f 14. ./contrib/llvm-project/libcxx/include/__memory/allocator_traits.h:298: DB::createMergeTreeSequentialSource(DB::MergeTreeSequentialSourceType, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::vector>, std::optional, std::shared_ptr>, bool, bool, bool) @ 0x000000002c810812 15. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1136: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::createMergedStream() @ 0x000000002c3dd079 16. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() @ 0x000000002c3d6516 17. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:534: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x000000002c3e2799 18. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::execute() @ 0x000000002c3ef3fe 19. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:0: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000002cc2f4c0 20. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000002c427f28 21. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000002c429675 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7eaf0 23. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001af8a79f 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 26. asan_thread_start(void*) @ 0x000000000aa43059 27. ? @ 0x00007f35aab92ac3 28. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:06:14.155800 [ 3168 ] {} test_3.part_log_profile_events_r2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.09.09 15:06:14.158996 [ 3160 ] {} test_3.part_header_r2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.09.09 15:06:14.160369 [ 3169 ] {} test_3.part_header_r1 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.09.09 15:06:14.165429 [ 3170 ] {} test_3.part_log_profile_events_r1 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.09.09 15:06:14.167592 [ 3156 ] {} test_3.test_03217_merge_replica_2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.09.09 15:06:14.170358 [ 3154 ] {} test_3.src (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.09.09 15:06:14.172595 [ 3175 ] {} test_3.test_03217_merge_replica_1 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.09.09 15:06:14.174262 [ 3171 ] {} test_15.primary_key (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.09.09 15:06:14.176511 [ 3159 ] {} test_1.order_by_all (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.09.09 15:06:14.223884 [ 3147 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:06:14.224376 [ 3176 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:06:14.230727 [ 3149 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:06:14.290171 [ 3162 ] {} test_3.part_header_r2 (ReplicatedMergeTreeCleanupThread): void DB::ReplicatedMergeTreeCleanupThread::run(): Code: 999. Coordination::Exception: Coordination error: Session expired, path /clickhouse/tables/00814_replicated_minimalistic_part_header_zookeeper_test_3/test_00814/part_header/s1/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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: Coordination::Exception::Exception(Coordination::Error, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x00000000264863d9 4. ./src/Common/ZooKeeper/IKeeper.h:501: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x00000000264847c3 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:373: zkutil::ZooKeeper::tryGetChildrenWatch(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000002e5ea628 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:346: zkutil::ZooKeeper::tryGetChildren(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr const&, Coordination::ListRequestType) @ 0x000000002e5e9d09 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:514: DB::ReplicatedMergeTreeCleanupThread::getBlocksSortedByTime(String const&, zkutil::ZooKeeper&, std::vector>&, std::map, std::less, std::allocator>>>&) @ 0x000000002ca25d67 8. ./contrib/llvm-project/libcxx/include/vector:553: DB::ReplicatedMergeTreeCleanupThread::clearOldBlocks(String const&, unsigned long, unsigned long, std::map, std::less, std::allocator>>>&) @ 0x000000002ca1d797 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x000000002ca153d0 10. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:50: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x000000002ca13666 11. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 13. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 16. asan_thread_start(void*) @ 0x000000000aa43059 17. ? @ 0x00007f35aab92ac3 18. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:06:14.292632 [ 3167 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. ./contrib/llvm-project/libcxx/include/string:1499: _ZN12Coordination9ExceptionC2IRA16_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x000000002e65bfe6 3. ./src/Common/ZooKeeper/IKeeper.h:0: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x000000002e6c2259 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1437: Coordination::ZooKeeper::list(String const&, Coordination::ListRequestType, std::function, std::shared_ptr>) @ 0x000000002e6caac6 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002e5e9637 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:299: zkutil::ZooKeeper::getChildrenImpl(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000002e5e8bfa 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:372: zkutil::ZooKeeper::tryGetChildrenWatch(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000002e5ea588 8. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:57: zkutil::ZooKeeper::getChildrenWatch(String const&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000002e5ea43b 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:914: DB::ReplicatedMergeTreeQueue::updateMutations(std::shared_ptr, std::shared_ptr>) @ 0x000000002ca8268c 10. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3622: DB::StorageReplicatedMergeTree::mutationsUpdatingTask() @ 0x000000002baf70bc 11. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 13. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 16. asan_thread_start(void*) @ 0x000000000aa43059 17. ? @ 0x00007f35aab92ac3 18. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:06:14.292826 [ 3153 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. ./contrib/llvm-project/libcxx/include/string:1499: _ZN12Coordination9ExceptionC2IRA16_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x000000002e65bfe6 3. ./src/Common/ZooKeeper/IKeeper.h:0: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x000000002e6c2259 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1437: Coordination::ZooKeeper::list(String const&, Coordination::ListRequestType, std::function, std::shared_ptr>) @ 0x000000002e6caac6 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002e5e9637 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:299: zkutil::ZooKeeper::getChildrenImpl(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000002e5e8bfa 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:372: zkutil::ZooKeeper::tryGetChildrenWatch(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000002e5ea588 8. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:57: zkutil::ZooKeeper::getChildrenWatch(String const&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000002e5ea43b 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:914: DB::ReplicatedMergeTreeQueue::updateMutations(std::shared_ptr, std::shared_ptr>) @ 0x000000002ca8268c 10. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3622: DB::StorageReplicatedMergeTree::mutationsUpdatingTask() @ 0x000000002baf70bc 11. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 13. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 16. asan_thread_start(void*) @ 0x000000000aa43059 17. ? @ 0x00007f35aab92ac3 18. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:06:14.315743 [ 3161 ] {} test_3.part_header_r1 (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. ./contrib/llvm-project/libcxx/include/string:1499: _ZN12Coordination9ExceptionC2IRA41_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x000000002cb2daa6 3. ./src/Common/ZooKeeper/IKeeper.h:509: _ZN12Coordination9Exception11fromMessageIRA41_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEES0_NS_5ErrorEOS5_ @ 0x000000002e6d1195 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1654: Coordination::ZooKeeper::maybeInjectSendFault() @ 0x000000002e6c26aa 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:0: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x000000002e6c1f3d 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1365: Coordination::ZooKeeper::exists(String const&, std::function, std::shared_ptr>) @ 0x000000002e6c8872 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002e5f1235 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002e5f076a 9. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:598: zkutil::ZooKeeper::existsWatch(String const&, Coordination::Stat*, std::function) @ 0x000000002e5f16a2 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002e5ebc63 11. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:203: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x000000002ca16d1a 12. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x000000002ca15340 13. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:50: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x000000002ca13666 14. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 16. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 19. asan_thread_start(void*) @ 0x000000000aa43059 20. ? @ 0x00007f35aab92ac3 21. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:06:14.919956 [ 2756 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:06:15.198141 [ 9284 ] {} test_3.mt_compact (41ca7238-8097-4c54-b235-fb77c8e4d21b): dropAllData: got exception removing parts from disk, removing successfully removed parts from memory. 2025.09.09 15:06:15.231415 [ 2771 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:06:15.232412 [ 9284 ] {} DatabaseCatalog: Cannot drop table test_3.mt_compact (41ca7238-8097-4c54-b235-fb77c8e4d21b). 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af819ed 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80746 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000263a174e 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002c47c445 8. ./contrib/llvm-project/libcxx/include/vector:547: DB::MergeTreeData::clearPartsFromFilesystem(std::vector, std::allocator>> const&, bool, std::unordered_set, std::equal_to, std::allocator>*) @ 0x000000002c47a78e 9. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::dropAllData() @ 0x000000002c4862d9 10. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::dropTableFinally(DB::DatabaseCatalog::TableMarkedAsDropped const&) @ 0x00000000286c7c77 11. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: void std::__function::__policy_invoker::__call_impl, std::allocator>>)::$_0, void ()>>(std::__function::__policy_storage const*) @ 0x00000000286d9744 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000263a3ea5 13. ./contrib/llvm-project/libcxx/include/future:0: std::packaged_task::operator()() @ 0x000000001bba33ac 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7eaf0 15. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001af8a79f 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 18. asan_thread_start(void*) @ 0x000000000aa43059 19. ? @ 0x00007f35aab92ac3 20. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:06:15.232857 [ 2769 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:06:15.233326 [ 2775 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:06:15.921838 [ 2834 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:06:16.234018 [ 2878 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:06:16.235367 [ 2868 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:06:16.265444 [ 2880 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:06:16.924995 [ 2954 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:06:17.236352 [ 2984 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:06:17.237677 [ 2972 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:06:17.267860 [ 2967 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:06:17.927280 [ 3077 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:06:18.243120 [ 3123 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:06:18.243650 [ 3109 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:06:18.269600 [ 3127 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:06:18.929844 [ 3202 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:06:19.245667 [ 3231 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:06:19.248701 [ 2752 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:06:19.271306 [ 2761 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:06:19.932632 [ 2821 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:06:20.248119 [ 2876 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:06:20.252034 [ 2870 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:06:20.273721 [ 2888 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:06:20.935046 [ 2949 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:06:21.251057 [ 3002 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:06:21.254927 [ 2984 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:06:21.275674 [ 2994 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:06:21.937453 [ 3038 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:06:22.253179 [ 3089 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:06:22.256980 [ 3079 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:06:22.277673 [ 3069 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:06:22.939709 [ 3151 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:06:23.254963 [ 3189 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:06:23.258718 [ 3188 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:06:23.279272 [ 3185 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:06:23.601294 [ 19252 ] {15706cf8-c31e-4f02-8b0a-531018a1bf8e} executeQuery: Code: 57. DB::Exception: Table test_3.t already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:48788) (comment: 03129_cte_with_final.sql) (in query: CREATE TABLE t (`key` Int64, `someCol` String, `eventTime` DateTime) ENGINE = ReplacingMergeTree(eventTime) ORDER BY key SETTINGS index_granularity = 60546, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = true, max_file_name_length = 20, min_bytes_for_full_part_storage = 0, compact_parts_max_bytes_to_buffer = 25265994, compact_parts_max_granules_to_buffer = 256, compact_parts_merge_max_bytes_to_prefetch_part = 2459204, merge_max_block_size = 23130, old_parts_lifetime = 10., prefer_fetch_merged_part_size_threshold = 10737418240, vertical_merge_algorithm_min_rows_to_activate = 1000000, vertical_merge_algorithm_min_columns_to_activate = 43, min_merge_bytes_to_use_direct_io = 196190332, index_granularity_bytes = 25942843, concurrent_part_removal_threshold = 100, allow_vertical_merges_from_compact_to_wide_parts = false, cache_populated_by_fetch = true, marks_compress_block_size = 11601, primary_key_compress_block_size = 28190), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa91e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1558: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291bc5ff 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291ac835 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000291c3415 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b382fc 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 15. asan_thread_start(void*) @ 0x000000000aa43059 16. ? @ 0x00007f35aab92ac3 17. ? @ 0x00007f35aac24850 2025.09.09 15:06:23.604878 [ 19252 ] {15706cf8-c31e-4f02-8b0a-531018a1bf8e} TCPHandler: Code: 57. DB::Exception: Table test_3.t already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa91e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1558: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291bc5ff 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291ac835 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000291c3415 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b382fc 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 15. asan_thread_start(void*) @ 0x000000000aa43059 16. ? @ 0x00007f35aab92ac3 17. ? @ 0x00007f35aac24850 2025.09.09 15:06:23.941883 [ 3236 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:06:24.258081 [ 3235 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:06:24.260439 [ 2764 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:06:24.281653 [ 2741 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:06:24.944803 [ 2864 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:06:25.260996 [ 2893 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:06:25.262931 [ 2895 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:06:25.387909 [ 2922 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:06:25.946957 [ 2953 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:06:26.099606 [ 19252 ] {f6b815a9-de25-438d-9b01-4c4baca883c0} executeQuery: Code: 57. DB::Exception: Table test_3.t already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:48800) (comment: 03151_unload_index_race.sh) (in query: CREATE TABLE t (`a` UInt32, `b` UInt32, `c` UInt32) ENGINE = MergeTree ORDER BY (a, b, c) SETTINGS index_granularity = 1, min_bytes_for_wide_part = 86622571, ratio_of_defaults_for_sparse_serialization = 0.28907620906829834, replace_long_file_name_to_hash = true, max_file_name_length = 128, min_bytes_for_full_part_storage = 0, compact_parts_max_bytes_to_buffer = 225355680, compact_parts_max_granules_to_buffer = 1, compact_parts_merge_max_bytes_to_prefetch_part = 22620805, merge_max_block_size = 2659, old_parts_lifetime = 480., prefer_fetch_merged_part_size_threshold = 10737418240, vertical_merge_algorithm_min_rows_to_activate = 1, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 10737418240, index_granularity_bytes = 16634435, concurrent_part_removal_threshold = 0, allow_vertical_merges_from_compact_to_wide_parts = true, cache_populated_by_fetch = true, marks_compress_block_size = 18234, primary_key_compress_block_size = 25270), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa91e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1558: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291bc5ff 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291ac835 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000291c3415 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b382fc 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 15. asan_thread_start(void*) @ 0x000000000aa43059 16. ? @ 0x00007f35aab92ac3 17. ? @ 0x00007f35aac24850 2025.09.09 15:06:26.102973 [ 19252 ] {f6b815a9-de25-438d-9b01-4c4baca883c0} TCPHandler: Code: 57. DB::Exception: Table test_3.t already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa91e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1558: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291bc5ff 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291ac835 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000291c3415 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b382fc 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 15. asan_thread_start(void*) @ 0x000000000aa43059 16. ? @ 0x00007f35aab92ac3 17. ? @ 0x00007f35aac24850 2025.09.09 15:06:26.263253 [ 2962 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:06:26.264837 [ 2975 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:06:26.391545 [ 3011 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:06:26.948937 [ 3022 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:06:27.265431 [ 3071 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:06:27.266586 [ 3085 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:06:27.393521 [ 3112 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:06:27.950942 [ 3166 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:06:28.270898 [ 3193 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:06:28.271402 [ 3187 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:06:28.402391 [ 3194 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:06:28.952927 [ 2740 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:06:29.275618 [ 2773 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:06:29.276474 [ 2769 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:06:29.405633 [ 2786 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:06:29.955281 [ 2839 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:06:30.277708 [ 2876 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:06:30.278742 [ 2846 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:06:30.407954 [ 2868 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:06:30.627317 [ 17365 ] {d7e8e0c4-97b4-421f-a166-8bbaa5ea899c} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=2, jobs=2). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:44660) (comment: 00988_parallel_parts_removal.sql) (in query: SELECT count(), sum(x) FROM mt;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af80b71 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af82f33 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002c64fc80 7. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1723: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr, unsigned long, std::shared_ptr, std::equal_to, std::allocator>>>, DB::MergeTreeData const&, std::vector> const&, std::shared_ptr, std::optional&, bool) @ 0x000000002de379fd 8. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1437: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000002de3554f 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:0: DB::ReadFromMergeTree::getAnalysisResult() const @ 0x000000002de41345 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:2022: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000002de4404c 11. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000002ddb933c 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000002ddff11e 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000002942117f 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x00000000294209e7 15. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b382fc 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 18. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 22. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:06:30.629639 [ 17365 ] {d7e8e0c4-97b4-421f-a166-8bbaa5ea899c} 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af80b71 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af82f33 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002c64fc80 7. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1723: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr, unsigned long, std::shared_ptr, std::equal_to, std::allocator>>>, DB::MergeTreeData const&, std::vector> const&, std::shared_ptr, std::optional&, bool) @ 0x000000002de379fd 8. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1437: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000002de3554f 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:0: DB::ReadFromMergeTree::getAnalysisResult() const @ 0x000000002de41345 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:2022: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000002de4404c 11. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000002ddb933c 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000002ddff11e 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000002942117f 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x00000000294209e7 15. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b382fc 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 18. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 22. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:06:30.957425 [ 2935 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:06:31.151894 [ 5446 ] {} test_0473czib.mt (37fd3cf2-879f-4934-ac8d-662471988a31): dropAllData: got exception removing parts from disk, removing successfully removed parts from memory. 2025.09.09 15:06:31.154883 [ 5446 ] {} DatabaseCatalog: Cannot drop table test_0473czib.mt (37fd3cf2-879f-4934-ac8d-662471988a31). 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af819ed 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80746 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000263a174e 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002c47c445 8. ./contrib/llvm-project/libcxx/include/vector:547: DB::MergeTreeData::clearPartsFromFilesystem(std::vector, std::allocator>> const&, bool, std::unordered_set, std::equal_to, std::allocator>*) @ 0x000000002c47a78e 9. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::dropAllData() @ 0x000000002c4862d9 10. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::dropTableFinally(DB::DatabaseCatalog::TableMarkedAsDropped const&) @ 0x00000000286c7c77 11. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: void std::__function::__policy_invoker::__call_impl, std::allocator>>)::$_0, void ()>>(std::__function::__policy_storage const*) @ 0x00000000286d9744 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000263a3ea5 13. ./contrib/llvm-project/libcxx/include/future:0: std::packaged_task::operator()() @ 0x000000001bba33ac 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7eaf0 15. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001af8a79f 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 18. asan_thread_start(void*) @ 0x000000000aa43059 19. ? @ 0x00007f35aab92ac3 20. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:06:31.279664 [ 2976 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:06:31.280406 [ 2968 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:06:31.409600 [ 2980 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:06:31.960055 [ 3016 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:06:32.281684 [ 3039 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:06:32.282113 [ 3054 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:06:32.415423 [ 3074 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:06:32.962260 [ 3118 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:06:33.291556 [ 3125 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:06:33.291819 [ 3152 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:06:33.417556 [ 3148 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:06:33.964474 [ 3203 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:06:34.293939 [ 3242 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:06:34.294058 [ 2734 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:06:34.419652 [ 3159 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:06:34.971775 [ 2796 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:06:35.295885 [ 2832 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:06:35.296346 [ 2831 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:06:35.421359 [ 2850 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:06:35.975394 [ 2905 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:06:36.297712 [ 2920 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:06:36.310800 [ 2931 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:06:36.423019 [ 2937 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:06:36.816237 [ 5908 ] {} test_0473czib.mt (37fd3cf2-879f-4934-ac8d-662471988a31): dropAllData: got exception removing parts from disk, removing successfully removed parts from memory. 2025.09.09 15:06:36.822586 [ 5908 ] {} DatabaseCatalog: Cannot drop table test_0473czib.mt (37fd3cf2-879f-4934-ac8d-662471988a31). 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af819ed 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80746 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000263a174e 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002c47c445 8. ./contrib/llvm-project/libcxx/include/vector:547: DB::MergeTreeData::clearPartsFromFilesystem(std::vector, std::allocator>> const&, bool, std::unordered_set, std::equal_to, std::allocator>*) @ 0x000000002c47a78e 9. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::dropAllData() @ 0x000000002c4862d9 10. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::dropTableFinally(DB::DatabaseCatalog::TableMarkedAsDropped const&) @ 0x00000000286c7c77 11. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: void std::__function::__policy_invoker::__call_impl, std::allocator>>)::$_0, void ()>>(std::__function::__policy_storage const*) @ 0x00000000286d9744 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000263a3ea5 13. ./contrib/llvm-project/libcxx/include/future:0: std::packaged_task::operator()() @ 0x000000001bba33ac 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7eaf0 15. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001af8a79f 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 18. asan_thread_start(void*) @ 0x000000000aa43059 19. ? @ 0x00007f35aab92ac3 20. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:06:36.978501 [ 2977 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:06:37.300409 [ 3027 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:06:37.313070 [ 3032 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:06:37.425181 [ 3042 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:06:37.982851 [ 3105 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:06:38.306898 [ 3113 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:06:38.315647 [ 3135 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:06:38.427658 [ 3136 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:06:38.984699 [ 3171 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:06:39.308706 [ 2757 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:06:39.317787 [ 2750 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:06:39.430331 [ 3234 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:06:39.886760 [ 4025 ] {046a6f63-c415-49e9-8b0c-d27387db6a24} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:44704) (comment: 01676_dictget_in_default_expression.sql) (in query: DROP DATABASE test_01676;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aac868e 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x00000000286b57c7 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x00000000291f5630 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:361: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000291edc97 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x00000000291ebf11 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x00000000291eb7ed 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b382fc 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 15:06:39.889059 [ 4025 ] {046a6f63-c415-49e9-8b0c-d27387db6a24} TCPHandler: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aac868e 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x00000000286b57c7 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x00000000291f5630 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:361: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000291edc97 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x00000000291ebf11 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x00000000291eb7ed 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b382fc 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 15:06:39.987089 [ 2769 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:06:40.310925 [ 2812 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:06:40.319785 [ 2814 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:06:40.432243 [ 2845 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:06:40.611275 [ 19252 ] {ea23c8b1-0714-475f-818b-66a93380fb22} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:52386) (comment: 01676_dictget_in_default_expression.sql) (in query: DROP DATABASE IF EXISTS test_01676 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aac868e 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x00000000286b57c7 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x00000000291f5630 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:361: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000291edc97 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x00000000291ebf11 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x00000000291eb7ed 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b382fc 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 15:06:40.625971 [ 19252 ] {ea23c8b1-0714-475f-818b-66a93380fb22} TCPHandler: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aac868e 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x00000000286b57c7 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x00000000291f5630 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:361: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000291edc97 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x00000000291ebf11 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x00000000291eb7ed 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b382fc 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 15:06:40.989048 [ 2875 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:06:41.250499 [ 2688 ] {4107a5d6-69dc-4b6f-ab7f-ebdc0038699c} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:52402) (comment: 01676_dictget_in_default_expression.sql) (in query: DROP DATABASE IF EXISTS test_01676 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aac868e 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x00000000286b57c7 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x00000000291f5630 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:361: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000291edc97 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x00000000291ebf11 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x00000000291eb7ed 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b382fc 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 15:06:41.259127 [ 2688 ] {4107a5d6-69dc-4b6f-ab7f-ebdc0038699c} TCPHandler: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aac868e 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x00000000286b57c7 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x00000000291f5630 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:361: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000291edc97 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x00000000291ebf11 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x00000000291eb7ed 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b382fc 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 15:06:41.313005 [ 2899 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:06:41.321429 [ 2903 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:06:41.435579 [ 2918 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:06:41.531990 [ 3340 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {44b09201-5a0e-4da3-91d1-ac60ea8508c5::202509_1_122_37}: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=13, 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af80b71 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80746 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002c765aab 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:1197: ? @ 0x000000002c7602b8 8. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x000000002c75fc2b 9. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:0: DB::MergeTreeReaderCompact::MergeTreeReaderCompact(std::shared_ptr, DB::NamesAndTypesList, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*, DB::MarkCache*, DB::MarkRanges, DB::MergeTreeReaderSettings, std::map, std::allocator>>, std::function const&, int) @ 0x000000002c7aee03 10. ./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.h:16: DB::MergeTreeReaderCompactSingleBuffer::MergeTreeReaderCompactSingleBuffer&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int&&) @ 0x000000002c5d6d21 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::MergeTreeDataPartCompact::getReader(DB::NamesAndTypesList const&, std::shared_ptr const&, DB::MarkRanges const&, std::unordered_map, std::equal_to, std::allocator>> const&, DB::UncompressedCache*, DB::MarkCache*, std::shared_ptr const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) const @ 0x000000002c5d1037 12. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:169: DB::MergeTreeSequentialSource::MergeTreeSequentialSource(DB::MergeTreeSequentialSourceType, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::vector>, std::optional, bool, bool, bool) @ 0x000000002c80c330 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:35: DB::MergeTreeSequentialSource* std::construct_at[abi:v15007] const&, std::shared_ptr&, std::shared_ptr&, std::vector>&, std::optional, bool, bool&, bool&, DB::MergeTreeSequentialSource*>(DB::MergeTreeSequentialSource*, DB::MergeTreeSequentialSourceType&, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr&, std::shared_ptr&, std::vector>&, std::optional&&, bool&&, bool&, bool&) @ 0x000000002c81320f 14. ./contrib/llvm-project/libcxx/include/__memory/allocator_traits.h:298: DB::createMergeTreeSequentialSource(DB::MergeTreeSequentialSourceType, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::vector>, std::optional, std::shared_ptr>, bool, bool, bool) @ 0x000000002c810812 15. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1136: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::createMergedStream() @ 0x000000002c3dd079 16. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() @ 0x000000002c3d6516 17. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:534: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x000000002c3e2799 18. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::execute() @ 0x000000002c3ef3fe 19. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:0: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000002cc2f4c0 20. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000002c427f28 21. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000002c429675 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7eaf0 23. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001af8a79f 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 26. asan_thread_start(void*) @ 0x000000000aa43059 27. ? @ 0x00007f35aab92ac3 28. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:06:41.959968 [ 17365 ] {96e2ee23-4ba5-427c-911b-67e24716a81d} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:52426) (comment: 01676_dictget_in_default_expression.sql) (in query: DROP DATABASE IF EXISTS test_01676 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aac868e 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x00000000286b57c7 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x00000000291f5630 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:361: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000291edc97 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x00000000291ebf11 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x00000000291eb7ed 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b382fc 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 15:06:41.966908 [ 17365 ] {96e2ee23-4ba5-427c-911b-67e24716a81d} TCPHandler: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aac868e 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x00000000286b57c7 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x00000000291f5630 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:361: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000291edc97 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x00000000291ebf11 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x00000000291eb7ed 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b382fc 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 15:06:41.991408 [ 2975 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:06:42.169924 [ 5906 ] {} test_0473czib.mt (37fd3cf2-879f-4934-ac8d-662471988a31): dropAllData: got exception removing parts from disk, removing successfully removed parts from memory. 2025.09.09 15:06:42.172040 [ 5906 ] {} DatabaseCatalog: Cannot drop table test_0473czib.mt (37fd3cf2-879f-4934-ac8d-662471988a31). Will retry later.: 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af819ed 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80746 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000263a174e 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002c47c445 8. ./contrib/llvm-project/libcxx/include/vector:547: DB::MergeTreeData::clearPartsFromFilesystem(std::vector, std::allocator>> const&, bool, std::unordered_set, std::equal_to, std::allocator>*) @ 0x000000002c47a78e 9. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::dropAllData() @ 0x000000002c4862d9 10. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::dropTableFinally(DB::DatabaseCatalog::TableMarkedAsDropped const&) @ 0x00000000286c7c77 11. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: void std::__function::__policy_invoker::__call_impl, std::allocator>>)::$_0, void ()>>(std::__function::__policy_storage const*) @ 0x00000000286d9744 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000263a3ea5 13. ./contrib/llvm-project/libcxx/include/future:0: std::packaged_task::operator()() @ 0x000000001bba33ac 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7eaf0 15. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001af8a79f 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 18. asan_thread_start(void*) @ 0x000000000aa43059 19. ? @ 0x00007f35aab92ac3 20. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:06:42.315474 [ 3023 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:06:42.327067 [ 3004 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:06:42.439100 [ 3016 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:06:42.993693 [ 3062 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:06:43.317324 [ 3081 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:06:43.328989 [ 3109 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:06:43.440950 [ 3126 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:06:43.996050 [ 3215 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:06:44.323238 [ 2746 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:06:44.330655 [ 2756 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:06:44.445115 [ 3160 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:06:44.767333 [ 3722 ] {a4a01e87-b2e9-4e9c-a854-73c25e8933ba} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=2, jobs=1). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:33158) (comment: 03151_unload_index_race.sh) (in query: SELECT count() AS `count()` FROM `test_3`.`t` AS `__table1` WHERE NOT ignore(`__table1`.`id`, `__table1`.`id2`, `__table1`.`id3`)), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af80b71 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af82f33 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002c64fc80 7. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1723: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr, unsigned long, std::shared_ptr, std::equal_to, std::allocator>>>, DB::MergeTreeData const&, std::vector> const&, std::shared_ptr, std::optional&, bool) @ 0x000000002de379fd 8. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1437: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000002de3554f 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:0: DB::ReadFromMergeTree::getAnalysisResult() const @ 0x000000002de41345 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:2022: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000002de4404c 11. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000002ddb933c 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000002ddff11e 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000002942117f 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x00000000294209e7 15. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b382fc 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 18. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 22. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:06:44.772768 [ 3722 ] {a4a01e87-b2e9-4e9c-a854-73c25e8933ba} 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af80b71 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af82f33 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002c64fc80 7. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1723: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr, unsigned long, std::shared_ptr, std::equal_to, std::allocator>>>, DB::MergeTreeData const&, std::vector> const&, std::shared_ptr, std::optional&, bool) @ 0x000000002de379fd 8. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1437: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000002de3554f 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:0: DB::ReadFromMergeTree::getAnalysisResult() const @ 0x000000002de41345 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:2022: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000002de4404c 11. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000002ddb933c 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000002ddff11e 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000002942117f 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x00000000294209e7 15. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b382fc 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 18. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 22. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:06:44.962816 [ 17365 ] {ad0bf61b-2629-429e-b091-cd61cb08294a} executeQuery: Code: 439. DB::Exception: Received from 127.0.0.7:9000. DB::Exception: Cannot schedule a task: fault injected (threads=2, jobs=1). Stack trace: 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af80b71 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af82f33 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002c64fc80 7. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1723: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr, unsigned long, std::shared_ptr, std::equal_to, std::allocator>>>, DB::MergeTreeData const&, std::vector> const&, std::shared_ptr, std::optional&, bool) @ 0x000000002de379fd 8. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1437: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000002de3554f 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:0: DB::ReadFromMergeTree::getAnalysisResult() const @ 0x000000002de41345 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:2022: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000002de4404c 11. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000002ddb933c 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000002ddff11e 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000002942117f 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x00000000294209e7 15. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b382fc 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 18. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 22. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 : While executing Remote. (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:52474) (comment: 03151_unload_index_race.sh) (in query: SELECT count() FROM t where not ignore(*);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. ./contrib/llvm-project/libcxx/include/string:1499: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x000000001aeb974e 3. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::Connection::receiveException() const @ 0x000000002cee6c6a 4. ./build_docker/./src/Client/Connection.cpp:0: DB::Connection::receivePacket() @ 0x000000002cef780e 5. ./build_docker/./src/Client/MultiplexedConnections.cpp:340: DB::MultiplexedConnections::receivePacketUnlocked(std::function) @ 0x000000002cf8e09e 6. ./build_docker/./src/QueryPipeline/RemoteQueryExecutorReadContext.cpp:0: DB::RemoteQueryExecutorReadContext::Task::run(std::function, std::function) @ 0x00000000278ad616 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000278ab436 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000278aaa44 9. ./contrib/boost/boost/context/fiber_ucontext.hpp:82: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x00000000278a8394 2025.09.09 15:06:44.974565 [ 17365 ] {ad0bf61b-2629-429e-b091-cd61cb08294a} TCPHandler: Code: 439. DB::Exception: Received from 127.0.0.7:9000. DB::Exception: Cannot schedule a task: fault injected (threads=2, jobs=1). Stack trace: 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af80b71 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af82f33 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002c64fc80 7. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1723: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr, unsigned long, std::shared_ptr, std::equal_to, std::allocator>>>, DB::MergeTreeData const&, std::vector> const&, std::shared_ptr, std::optional&, bool) @ 0x000000002de379fd 8. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1437: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000002de3554f 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:0: DB::ReadFromMergeTree::getAnalysisResult() const @ 0x000000002de41345 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:2022: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000002de4404c 11. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000002ddb933c 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000002ddff11e 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000002942117f 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x00000000294209e7 15. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b382fc 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 18. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 22. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 : 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. ./contrib/llvm-project/libcxx/include/string:1499: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x000000001aeb974e 3. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::Connection::receiveException() const @ 0x000000002cee6c6a 4. ./build_docker/./src/Client/Connection.cpp:0: DB::Connection::receivePacket() @ 0x000000002cef780e 5. ./build_docker/./src/Client/MultiplexedConnections.cpp:340: DB::MultiplexedConnections::receivePacketUnlocked(std::function) @ 0x000000002cf8e09e 6. ./build_docker/./src/QueryPipeline/RemoteQueryExecutorReadContext.cpp:0: DB::RemoteQueryExecutorReadContext::Task::run(std::function, std::function) @ 0x00000000278ad616 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000278ab436 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000278aaa44 9. ./contrib/boost/boost/context/fiber_ucontext.hpp:82: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x00000000278a8394 2025.09.09 15:06:44.997586 [ 2823 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:06:45.032468 [ 3766 ] {721c5d8b-309e-4dff-bbcb-5e7b3a7202ac} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=2, jobs=2). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:46826) (comment: 03151_unload_index_race.sh) (in query: SELECT count() AS `count()` FROM `test_3`.`t` AS `__table1` WHERE NOT ignore(`__table1`.`id`, `__table1`.`id2`, `__table1`.`id3`)), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af80b71 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af82f33 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002c64fc80 7. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1723: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr, unsigned long, std::shared_ptr, std::equal_to, std::allocator>>>, DB::MergeTreeData const&, std::vector> const&, std::shared_ptr, std::optional&, bool) @ 0x000000002de379fd 8. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1437: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000002de3554f 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:0: DB::ReadFromMergeTree::getAnalysisResult() const @ 0x000000002de41345 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:2022: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000002de4404c 11. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000002ddb933c 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000002ddff11e 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000002942117f 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x00000000294209e7 15. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b382fc 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 18. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 22. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:06:45.100585 [ 3766 ] {721c5d8b-309e-4dff-bbcb-5e7b3a7202ac} 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af80b71 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af82f33 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002c64fc80 7. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1723: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr, unsigned long, std::shared_ptr, std::equal_to, std::allocator>>>, DB::MergeTreeData const&, std::vector> const&, std::shared_ptr, std::optional&, bool) @ 0x000000002de379fd 8. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1437: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000002de3554f 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:0: DB::ReadFromMergeTree::getAnalysisResult() const @ 0x000000002de41345 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:2022: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000002de4404c 11. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000002ddb933c 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000002ddff11e 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000002942117f 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x00000000294209e7 15. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b382fc 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 18. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 22. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:06:45.147189 [ 4025 ] {8de3399c-b4b9-4439-a5f0-4b5fd0a1b268} executeQuery: Code: 210. DB::Exception: Connection reset by peer, while writing to socket ([::ffff:127.0.0.10]:9000 -> [::ffff:127.0.0.1]:48428): While executing MergeTreeSelect(pool: ReadPoolParallelReplicas, algorithm: Thread). (NETWORK_ERROR) (version 24.8.14.10505.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:48428) (comment: 03151_unload_index_race.sh) (in query: SELECT count() AS `count()` FROM `test_3`.`t` AS `__table1` WHERE NOT ignore(`__table1`.`id`, `__table1`.`id2`, `__table1`.`id3`)), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 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&&) @ 0x000000001b0b7a5f 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:158: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000001b0bab02 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:201: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000002cf09bf7 5. ./src/IO/WriteBuffer.h:66: DB::TCPHandler::sendMergeTreeReadTaskRequestAssumeLocked(DB::ParallelReadRequest) @ 0x000000002d198e17 6. ./build_docker/./src/Server/TCPHandler.cpp:561: std::optional std::__function::__policy_invoker (DB::ParallelReadRequest)>::__call_impl (DB::ParallelReadRequest)>>(std::__function::__policy_storage const*, DB::ParallelReadRequest&&) @ 0x000000002d1acdee 7. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:34: std::optional std::__function::__policy_invoker (DB::ParallelReadRequest)>::__call_impl (DB::ParallelReadRequest)>>, std::optional (DB::ParallelReadRequest)>>(std::__function::__policy_storage const*, DB::ParallelReadRequest&&) @ 0x000000002c826519 8. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:81: DB::ParallelReadingExtension::sendReadRequest(DB::CoordinationMode, unsigned long, DB::RangesInDataPartsDescription const&) const @ 0x000000002c820016 9. ./contrib/llvm-project/libcxx/include/deque:1198: DB::MergeTreeReadPoolParallelReplicas::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x000000002deeadbc 10. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:0: DB::MergeTreeSelectProcessor::read() @ 0x000000002c8241d2 11. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000002de6d77a 12. ./build_docker/./src/Processors/ISource.cpp:0: DB::ISource::work() @ 0x000000002d3290a1 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:381: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000002d34bd35 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7eaf0 17. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001af8a79f 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 20. asan_thread_start(void*) @ 0x000000000aa43059 21. ? @ 0x00007f35aab92ac3 22. ? @ 0x00007f35aac24850 2025.09.09 15:06:45.155921 [ 4025 ] {8de3399c-b4b9-4439-a5f0-4b5fd0a1b268} TCPHandler: Can't send logs to client: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::ffff:127.0.0.10]:9000 -> [::ffff:127.0.0.1]:48428). (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 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&&) @ 0x000000001b0b7a5f 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:169: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000001b0bada2 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:201: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000002cf09bf7 5. ./src/IO/WriteBuffer.h:66: DB::TCPHandler::sendLogData(DB::Block const&) @ 0x000000002d1a9beb 6. ./contrib/llvm-project/libcxx/include/__hash_table:1473: DB::TCPHandler::sendLogs() @ 0x000000002d18db59 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d176902 8. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 12. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 13. asan_thread_start(void*) @ 0x000000000aa43059 14. ? @ 0x00007f35aab92ac3 15. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:06:45.159008 [ 4025 ] {8de3399c-b4b9-4439-a5f0-4b5fd0a1b268} TCPHandler: Code: 210. DB::Exception: Connection reset by peer, while writing to socket ([::ffff:127.0.0.10]:9000 -> [::ffff:127.0.0.1]:48428): While executing MergeTreeSelect(pool: ReadPoolParallelReplicas, algorithm: Thread). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 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&&) @ 0x000000001b0b7a5f 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:158: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000001b0bab02 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:201: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000002cf09bf7 5. ./src/IO/WriteBuffer.h:66: DB::TCPHandler::sendMergeTreeReadTaskRequestAssumeLocked(DB::ParallelReadRequest) @ 0x000000002d198e17 6. ./build_docker/./src/Server/TCPHandler.cpp:561: std::optional std::__function::__policy_invoker (DB::ParallelReadRequest)>::__call_impl (DB::ParallelReadRequest)>>(std::__function::__policy_storage const*, DB::ParallelReadRequest&&) @ 0x000000002d1acdee 7. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:34: std::optional std::__function::__policy_invoker (DB::ParallelReadRequest)>::__call_impl (DB::ParallelReadRequest)>>, std::optional (DB::ParallelReadRequest)>>(std::__function::__policy_storage const*, DB::ParallelReadRequest&&) @ 0x000000002c826519 8. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:81: DB::ParallelReadingExtension::sendReadRequest(DB::CoordinationMode, unsigned long, DB::RangesInDataPartsDescription const&) const @ 0x000000002c820016 9. ./contrib/llvm-project/libcxx/include/deque:1198: DB::MergeTreeReadPoolParallelReplicas::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x000000002deeadbc 10. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:0: DB::MergeTreeSelectProcessor::read() @ 0x000000002c8241d2 11. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000002de6d77a 12. ./build_docker/./src/Processors/ISource.cpp:0: DB::ISource::work() @ 0x000000002d3290a1 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:381: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000002d34bd35 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7eaf0 17. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001af8a79f 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 20. asan_thread_start(void*) @ 0x000000000aa43059 21. ? @ 0x00007f35aab92ac3 22. ? @ 0x00007f35aac24850 2025.09.09 15:06:45.163915 [ 4025 ] {8de3399c-b4b9-4439-a5f0-4b5fd0a1b268} TCPHandler: Client has gone away. 2025.09.09 15:06:45.324932 [ 2841 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:06:45.332242 [ 2834 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:06:45.447738 [ 2837 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:06:45.538698 [ 20338 ] {209cbca3-78d1-4c79-a20b-ffe16e2516d6} executeQuery: Code: 439. DB::Exception: Received from 127.0.0.4:9000. DB::Exception: Cannot schedule a task: fault injected (threads=2, jobs=2). Stack trace: 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af80b71 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af82f33 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002c64fc80 7. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1723: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr, unsigned long, std::shared_ptr, std::equal_to, std::allocator>>>, DB::MergeTreeData const&, std::vector> const&, std::shared_ptr, std::optional&, bool) @ 0x000000002de379fd 8. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1437: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000002de3554f 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:0: DB::ReadFromMergeTree::getAnalysisResult() const @ 0x000000002de41345 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:2022: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000002de4404c 11. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000002ddb933c 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000002ddff11e 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000002942117f 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x00000000294209e7 15. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b382fc 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 18. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 22. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 : While executing Remote. (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:52492) (comment: 03151_unload_index_race.sh) (in query: SELECT count() FROM t where not ignore(*);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. ./contrib/llvm-project/libcxx/include/string:1499: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x000000001aeb974e 3. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::Connection::receiveException() const @ 0x000000002cee6c6a 4. ./build_docker/./src/Client/Connection.cpp:0: DB::Connection::receivePacket() @ 0x000000002cef780e 5. ./build_docker/./src/Client/MultiplexedConnections.cpp:340: DB::MultiplexedConnections::receivePacketUnlocked(std::function) @ 0x000000002cf8e09e 6. ./build_docker/./src/QueryPipeline/RemoteQueryExecutorReadContext.cpp:0: DB::RemoteQueryExecutorReadContext::Task::run(std::function, std::function) @ 0x00000000278ad616 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000278ab436 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000278aaa44 9. ./contrib/boost/boost/context/fiber_ucontext.hpp:82: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x00000000278a8394 2025.09.09 15:06:45.543499 [ 3612 ] {} ServerErrorHandler: Code: 210. DB::NetException: Connection reset by peer, while reading from socket (peer: [::ffff:127.0.0.1]:45786, local: [::ffff:127.0.0.6]:9000). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 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&&) @ 0x000000001b0b7a5f 3. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:83: DB::ReadBufferFromPocoSocketBase::socketReceiveBytesImpl(char*, unsigned long) @ 0x000000001b0b6042 4. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:107: DB::ReadBufferFromPocoSocketBase::nextImpl() @ 0x000000001b0b6b84 5. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:103: DB::ReadBufferFromPocoSocketChunked::nextImpl() @ 0x000000002cf045f6 6. DB::ReadBuffer::next() @ 0x000000000b528aeb 7. ./build_docker/./src/Server/TCPHandler.cpp:383: DB::TCPHandler::runImpl() @ 0x000000002d174fd3 8. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 12. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 13. asan_thread_start(void*) @ 0x000000000aa43059 14. ? @ 0x00007f35aab92ac3 15. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:06:45.544816 [ 20338 ] {209cbca3-78d1-4c79-a20b-ffe16e2516d6} TCPHandler: Code: 439. DB::Exception: Received from 127.0.0.4:9000. DB::Exception: Cannot schedule a task: fault injected (threads=2, jobs=2). Stack trace: 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af80b71 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af82f33 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002c64fc80 7. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1723: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr, unsigned long, std::shared_ptr, std::equal_to, std::allocator>>>, DB::MergeTreeData const&, std::vector> const&, std::shared_ptr, std::optional&, bool) @ 0x000000002de379fd 8. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1437: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000002de3554f 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:0: DB::ReadFromMergeTree::getAnalysisResult() const @ 0x000000002de41345 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:2022: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000002de4404c 11. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000002ddb933c 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000002ddff11e 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000002942117f 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x00000000294209e7 15. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b382fc 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 18. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 22. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 : 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. ./contrib/llvm-project/libcxx/include/string:1499: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x000000001aeb974e 3. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::Connection::receiveException() const @ 0x000000002cee6c6a 4. ./build_docker/./src/Client/Connection.cpp:0: DB::Connection::receivePacket() @ 0x000000002cef780e 5. ./build_docker/./src/Client/MultiplexedConnections.cpp:340: DB::MultiplexedConnections::receivePacketUnlocked(std::function) @ 0x000000002cf8e09e 6. ./build_docker/./src/QueryPipeline/RemoteQueryExecutorReadContext.cpp:0: DB::RemoteQueryExecutorReadContext::Task::run(std::function, std::function) @ 0x00000000278ad616 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000278ab436 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000278aaa44 9. ./contrib/boost/boost/context/fiber_ucontext.hpp:82: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x00000000278a8394 2025.09.09 15:06:45.694209 [ 20379 ] {eb2d4db5-8031-4eac-a303-ee827d1f9987} 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.10505.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:41000) (comment: 03151_unload_index_race.sh) (in query: SELECT count() AS `count()` FROM `test_3`.`t` AS `__table1` WHERE NOT ignore(`__table1`.`id`, `__table1`.`id2`, `__table1`.`id3`)), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af819ed 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80746 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d34b5ca 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000002d3486e4 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000002d34827b 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002d36bcf7 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 12. asan_thread_start(void*) @ 0x000000000aa43059 13. ? @ 0x00007f35aab92ac3 14. ? @ 0x00007f35aac24850 2025.09.09 15:06:45.728923 [ 20379 ] {eb2d4db5-8031-4eac-a303-ee827d1f9987} 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af819ed 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80746 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d34b5ca 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000002d3486e4 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000002d34827b 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002d36bcf7 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 12. asan_thread_start(void*) @ 0x000000000aa43059 13. ? @ 0x00007f35aab92ac3 14. ? @ 0x00007f35aac24850 2025.09.09 15:06:45.737342 [ 20380 ] {88e7ad37-e6e8-4a3c-9ce2-ea246b013ae0} executeQuery: Code: 210. DB::Exception: I/O error: Broken pipe, while writing to socket ([::ffff:127.0.0.10]:9000 -> [::ffff:127.0.0.1]:48448): While executing MergeTreeSelect(pool: ReadPoolParallelReplicas, algorithm: Thread). (NETWORK_ERROR) (version 24.8.14.10505.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:48448) (comment: 03151_unload_index_race.sh) (in query: SELECT count() AS `count()` FROM `test_3`.`t` AS `__table1` WHERE NOT ignore(`__table1`.`id`, `__table1`.`id2`, `__table1`.`id3`)), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 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&&) @ 0x000000001b0b7a5f 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:169: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000001b0bada2 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:201: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000002cf09bf7 5. ./src/IO/WriteBuffer.h:66: DB::TCPHandler::sendMergeTreeReadTaskRequestAssumeLocked(DB::ParallelReadRequest) @ 0x000000002d198e17 6. ./build_docker/./src/Server/TCPHandler.cpp:561: std::optional std::__function::__policy_invoker (DB::ParallelReadRequest)>::__call_impl (DB::ParallelReadRequest)>>(std::__function::__policy_storage const*, DB::ParallelReadRequest&&) @ 0x000000002d1acdee 7. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:34: std::optional std::__function::__policy_invoker (DB::ParallelReadRequest)>::__call_impl (DB::ParallelReadRequest)>>, std::optional (DB::ParallelReadRequest)>>(std::__function::__policy_storage const*, DB::ParallelReadRequest&&) @ 0x000000002c826519 8. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:81: DB::ParallelReadingExtension::sendReadRequest(DB::CoordinationMode, unsigned long, DB::RangesInDataPartsDescription const&) const @ 0x000000002c820016 9. ./contrib/llvm-project/libcxx/include/deque:1198: DB::MergeTreeReadPoolParallelReplicas::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x000000002deeadbc 10. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:0: DB::MergeTreeSelectProcessor::read() @ 0x000000002c8241d2 11. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000002de6d77a 12. ./build_docker/./src/Processors/ISource.cpp:0: DB::ISource::work() @ 0x000000002d3290a1 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:381: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000002d34bd35 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7eaf0 17. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001af8a79f 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 20. asan_thread_start(void*) @ 0x000000000aa43059 21. ? @ 0x00007f35aab92ac3 22. ? @ 0x00007f35aac24850 2025.09.09 15:06:45.758989 [ 20380 ] {88e7ad37-e6e8-4a3c-9ce2-ea246b013ae0} TCPHandler: Can't send logs to client: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::ffff:127.0.0.10]:9000 -> [::ffff:127.0.0.1]:48448). (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 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&&) @ 0x000000001b0b7a5f 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:169: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000001b0bada2 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:201: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000002cf09bf7 5. ./src/IO/WriteBuffer.h:66: DB::TCPHandler::sendLogData(DB::Block const&) @ 0x000000002d1a9beb 6. ./contrib/llvm-project/libcxx/include/__hash_table:1473: DB::TCPHandler::sendLogs() @ 0x000000002d18db59 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d176902 8. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 12. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 13. asan_thread_start(void*) @ 0x000000000aa43059 14. ? @ 0x00007f35aab92ac3 15. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:06:45.773091 [ 20380 ] {88e7ad37-e6e8-4a3c-9ce2-ea246b013ae0} TCPHandler: Code: 210. DB::Exception: I/O error: Broken pipe, while writing to socket ([::ffff:127.0.0.10]:9000 -> [::ffff:127.0.0.1]:48448): While executing MergeTreeSelect(pool: ReadPoolParallelReplicas, algorithm: Thread). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 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&&) @ 0x000000001b0b7a5f 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:169: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000001b0bada2 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:201: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000002cf09bf7 5. ./src/IO/WriteBuffer.h:66: DB::TCPHandler::sendMergeTreeReadTaskRequestAssumeLocked(DB::ParallelReadRequest) @ 0x000000002d198e17 6. ./build_docker/./src/Server/TCPHandler.cpp:561: std::optional std::__function::__policy_invoker (DB::ParallelReadRequest)>::__call_impl (DB::ParallelReadRequest)>>(std::__function::__policy_storage const*, DB::ParallelReadRequest&&) @ 0x000000002d1acdee 7. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:34: std::optional std::__function::__policy_invoker (DB::ParallelReadRequest)>::__call_impl (DB::ParallelReadRequest)>>, std::optional (DB::ParallelReadRequest)>>(std::__function::__policy_storage const*, DB::ParallelReadRequest&&) @ 0x000000002c826519 8. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:81: DB::ParallelReadingExtension::sendReadRequest(DB::CoordinationMode, unsigned long, DB::RangesInDataPartsDescription const&) const @ 0x000000002c820016 9. ./contrib/llvm-project/libcxx/include/deque:1198: DB::MergeTreeReadPoolParallelReplicas::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x000000002deeadbc 10. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:0: DB::MergeTreeSelectProcessor::read() @ 0x000000002c8241d2 11. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000002de6d77a 12. ./build_docker/./src/Processors/ISource.cpp:0: DB::ISource::work() @ 0x000000002d3290a1 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:381: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000002d34bd35 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7eaf0 17. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001af8a79f 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 20. asan_thread_start(void*) @ 0x000000000aa43059 21. ? @ 0x00007f35aab92ac3 22. ? @ 0x00007f35aac24850 2025.09.09 15:06:45.810288 [ 20343 ] {ebdf2aba-c115-4bdf-8b31-deef3a1566e8} executeQuery: Code: 439. DB::Exception: Received from 127.0.0.3:9000. DB::Exception: Cannot schedule a task: failed to start the thread (threads=1, jobs=1). Stack trace: 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af819ed 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80746 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d34b5ca 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000002d3486e4 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000002d34827b 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002d36bcf7 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 12. asan_thread_start(void*) @ 0x000000000aa43059 13. ? @ 0x00007f35aab92ac3 14. ? @ 0x00007f35aac24850 : While executing Remote. (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:52502) (comment: 03151_unload_index_race.sh) (in query: SELECT count() FROM t where not ignore(*);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. ./contrib/llvm-project/libcxx/include/string:1499: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x000000001aeb974e 3. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::Connection::receiveException() const @ 0x000000002cee6c6a 4. ./build_docker/./src/Client/Connection.cpp:0: DB::Connection::receivePacket() @ 0x000000002cef780e 5. ./build_docker/./src/Client/MultiplexedConnections.cpp:340: DB::MultiplexedConnections::receivePacketUnlocked(std::function) @ 0x000000002cf8e09e 6. ./build_docker/./src/QueryPipeline/RemoteQueryExecutorReadContext.cpp:0: DB::RemoteQueryExecutorReadContext::Task::run(std::function, std::function) @ 0x00000000278ad616 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000278ab436 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000278aaa44 9. ./contrib/boost/boost/context/fiber_ucontext.hpp:82: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x00000000278a8394 2025.09.09 15:06:45.829724 [ 20343 ] {ebdf2aba-c115-4bdf-8b31-deef3a1566e8} TCPHandler: Code: 439. DB::Exception: Received from 127.0.0.3:9000. DB::Exception: Cannot schedule a task: failed to start the thread (threads=1, jobs=1). Stack trace: 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af819ed 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80746 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d34b5ca 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000002d3486e4 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000002d34827b 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002d36bcf7 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 12. asan_thread_start(void*) @ 0x000000000aa43059 13. ? @ 0x00007f35aab92ac3 14. ? @ 0x00007f35aac24850 : 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. ./contrib/llvm-project/libcxx/include/string:1499: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x000000001aeb974e 3. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::Connection::receiveException() const @ 0x000000002cee6c6a 4. ./build_docker/./src/Client/Connection.cpp:0: DB::Connection::receivePacket() @ 0x000000002cef780e 5. ./build_docker/./src/Client/MultiplexedConnections.cpp:340: DB::MultiplexedConnections::receivePacketUnlocked(std::function) @ 0x000000002cf8e09e 6. ./build_docker/./src/QueryPipeline/RemoteQueryExecutorReadContext.cpp:0: DB::RemoteQueryExecutorReadContext::Task::run(std::function, std::function) @ 0x00000000278ad616 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000278ab436 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000278aaa44 9. ./contrib/boost/boost/context/fiber_ucontext.hpp:82: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x00000000278a8394 2025.09.09 15:06:45.875141 [ 20380 ] {88e7ad37-e6e8-4a3c-9ce2-ea246b013ae0} TCPHandler: Client has gone away. 2025.09.09 15:06:45.879176 [ 3722 ] {ba3daa9c-a587-4af2-9bfc-d0629ba70813} executeQuery: Code: 210. DB::Exception: Connection reset by peer, while writing to socket ([::ffff:127.0.0.9]:9000 -> [::ffff:127.0.0.1]:42982): While executing MergeTreeSelect(pool: ReadPoolParallelReplicas, algorithm: Thread). (NETWORK_ERROR) (version 24.8.14.10505.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:42982) (comment: 03151_unload_index_race.sh) (in query: SELECT count() AS `count()` FROM `test_3`.`t` AS `__table1` WHERE NOT ignore(`__table1`.`id`, `__table1`.`id2`, `__table1`.`id3`)), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 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&&) @ 0x000000001b0b7a5f 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:158: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000001b0bab02 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:201: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000002cf09bf7 5. ./src/IO/WriteBuffer.h:66: DB::TCPHandler::sendMergeTreeReadTaskRequestAssumeLocked(DB::ParallelReadRequest) @ 0x000000002d198e17 6. ./build_docker/./src/Server/TCPHandler.cpp:561: std::optional std::__function::__policy_invoker (DB::ParallelReadRequest)>::__call_impl (DB::ParallelReadRequest)>>(std::__function::__policy_storage const*, DB::ParallelReadRequest&&) @ 0x000000002d1acdee 7. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:34: std::optional std::__function::__policy_invoker (DB::ParallelReadRequest)>::__call_impl (DB::ParallelReadRequest)>>, std::optional (DB::ParallelReadRequest)>>(std::__function::__policy_storage const*, DB::ParallelReadRequest&&) @ 0x000000002c826519 8. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:81: DB::ParallelReadingExtension::sendReadRequest(DB::CoordinationMode, unsigned long, DB::RangesInDataPartsDescription const&) const @ 0x000000002c820016 9. ./contrib/llvm-project/libcxx/include/deque:1198: DB::MergeTreeReadPoolParallelReplicas::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x000000002deeadbc 10. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:0: DB::MergeTreeSelectProcessor::read() @ 0x000000002c8241d2 11. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000002de6d77a 12. ./build_docker/./src/Processors/ISource.cpp:0: DB::ISource::work() @ 0x000000002d3290a1 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:381: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000002d34bd35 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7eaf0 17. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001af8a79f 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 20. asan_thread_start(void*) @ 0x000000000aa43059 21. ? @ 0x00007f35aab92ac3 22. ? @ 0x00007f35aac24850 2025.09.09 15:06:45.887677 [ 3722 ] {ba3daa9c-a587-4af2-9bfc-d0629ba70813} TCPHandler: Can't send logs to client: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::ffff:127.0.0.9]:9000 -> [::ffff:127.0.0.1]:42982). (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 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&&) @ 0x000000001b0b7a5f 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:169: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000001b0bada2 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:201: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000002cf09bf7 5. ./src/IO/WriteBuffer.h:66: DB::TCPHandler::sendLogData(DB::Block const&) @ 0x000000002d1a9beb 6. ./contrib/llvm-project/libcxx/include/__hash_table:1473: DB::TCPHandler::sendLogs() @ 0x000000002d18db59 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d176902 8. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 12. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 13. asan_thread_start(void*) @ 0x000000000aa43059 14. ? @ 0x00007f35aab92ac3 15. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:06:45.891564 [ 3722 ] {ba3daa9c-a587-4af2-9bfc-d0629ba70813} TCPHandler: Code: 210. DB::Exception: Connection reset by peer, while writing to socket ([::ffff:127.0.0.9]:9000 -> [::ffff:127.0.0.1]:42982): While executing MergeTreeSelect(pool: ReadPoolParallelReplicas, algorithm: Thread). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 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&&) @ 0x000000001b0b7a5f 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:158: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000001b0bab02 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:201: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000002cf09bf7 5. ./src/IO/WriteBuffer.h:66: DB::TCPHandler::sendMergeTreeReadTaskRequestAssumeLocked(DB::ParallelReadRequest) @ 0x000000002d198e17 6. ./build_docker/./src/Server/TCPHandler.cpp:561: std::optional std::__function::__policy_invoker (DB::ParallelReadRequest)>::__call_impl (DB::ParallelReadRequest)>>(std::__function::__policy_storage const*, DB::ParallelReadRequest&&) @ 0x000000002d1acdee 7. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:34: std::optional std::__function::__policy_invoker (DB::ParallelReadRequest)>::__call_impl (DB::ParallelReadRequest)>>, std::optional (DB::ParallelReadRequest)>>(std::__function::__policy_storage const*, DB::ParallelReadRequest&&) @ 0x000000002c826519 8. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:81: DB::ParallelReadingExtension::sendReadRequest(DB::CoordinationMode, unsigned long, DB::RangesInDataPartsDescription const&) const @ 0x000000002c820016 9. ./contrib/llvm-project/libcxx/include/deque:1198: DB::MergeTreeReadPoolParallelReplicas::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x000000002deeadbc 10. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:0: DB::MergeTreeSelectProcessor::read() @ 0x000000002c8241d2 11. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000002de6d77a 12. ./build_docker/./src/Processors/ISource.cpp:0: DB::ISource::work() @ 0x000000002d3290a1 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:381: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000002d34bd35 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7eaf0 17. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001af8a79f 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 20. asan_thread_start(void*) @ 0x000000000aa43059 21. ? @ 0x00007f35aab92ac3 22. ? @ 0x00007f35aac24850 2025.09.09 15:06:45.893048 [ 3722 ] {ba3daa9c-a587-4af2-9bfc-d0629ba70813} TCPHandler: Client has gone away. 2025.09.09 15:06:46.000956 [ 2894 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:06:46.365811 [ 2948 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:06:46.378685 [ 2960 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:06:46.449559 [ 2952 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:06:47.044033 [ 3010 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:06:47.198270 [ 20171 ] {} test_0473czib.mt (37fd3cf2-879f-4934-ac8d-662471988a31): dropAllData: got exception removing parts from disk, removing successfully removed parts from memory. 2025.09.09 15:06:47.199771 [ 20171 ] {} DatabaseCatalog: Cannot drop table test_0473czib.mt (37fd3cf2-879f-4934-ac8d-662471988a31). 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af819ed 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80746 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000263a174e 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002c47c445 8. ./contrib/llvm-project/libcxx/include/vector:547: DB::MergeTreeData::clearPartsFromFilesystem(std::vector, std::allocator>> const&, bool, std::unordered_set, std::equal_to, std::allocator>*) @ 0x000000002c47a78e 9. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::dropAllData() @ 0x000000002c4862d9 10. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::dropTableFinally(DB::DatabaseCatalog::TableMarkedAsDropped const&) @ 0x00000000286c7c77 11. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: void std::__function::__policy_invoker::__call_impl, std::allocator>>)::$_0, void ()>>(std::__function::__policy_storage const*) @ 0x00000000286d9744 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000263a3ea5 13. ./contrib/llvm-project/libcxx/include/future:0: std::packaged_task::operator()() @ 0x000000001bba33ac 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7eaf0 15. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001af8a79f 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 18. asan_thread_start(void*) @ 0x000000000aa43059 19. ? @ 0x00007f35aab92ac3 20. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:06:47.403095 [ 3063 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:06:47.403479 [ 3033 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:06:47.451071 [ 3074 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:06:47.873933 [ 20397 ] {9e1da50f-868b-495f-95e4-e6f0fdff1fae} 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.10505.altinitytest (altinity build)) (from [::1]:52568) (comment: 02421_simple_queries_for_opentelemetry.sh) (in query: SELECT attribute['db.statement'] as query, attribute['clickhouse.read_rows'] as read_rows, attribute['clickhouse.written_rows'] as written_rows FROM system.opentelemetry_span_log WHERE finish_date >= yesterday() AND operation_name = 'query' AND attribute['clickhouse.query_id'] = 'fd19fb47-b9e0-425c-ab89-03b7b7a913c7' 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af819ed 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80746 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d34b5ca 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000002d3486e4 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000002d34827b 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002d36bcf7 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 12. asan_thread_start(void*) @ 0x000000000aa43059 13. ? @ 0x00007f35aab92ac3 14. ? @ 0x00007f35aac24850 2025.09.09 15:06:47.885700 [ 20397 ] {9e1da50f-868b-495f-95e4-e6f0fdff1fae} 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af819ed 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80746 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d34b5ca 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000002d3486e4 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000002d34827b 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002d36bcf7 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 12. asan_thread_start(void*) @ 0x000000000aa43059 13. ? @ 0x00007f35aab92ac3 14. ? @ 0x00007f35aac24850 2025.09.09 15:06:48.045633 [ 3127 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:06:48.079377 [ 20353 ] {8ec80e5e-70b0-49df-bc7f-125661eedbd6} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=790, jobs=736). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:59348) (comment: 03151_unload_index_race.sh) (in query: SELECT count() FROM t where not ignore(*);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af872f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af7b2d1 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af7c3f3 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d36920d 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000002d369e5f 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processOrdinaryQuery() @ 0x000000002d18af7b 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d17644a 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 15. asan_thread_start(void*) @ 0x000000000aa43059 16. ? @ 0x00007f35aab92ac3 17. ? @ 0x00007f35aac24850 2025.09.09 15:06:48.081019 [ 20353 ] {8ec80e5e-70b0-49df-bc7f-125661eedbd6} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=790, jobs=736). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af872f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af7b2d1 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af7c3f3 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d36920d 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000002d369e5f 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processOrdinaryQuery() @ 0x000000002d18af7b 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d17644a 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 15. asan_thread_start(void*) @ 0x000000000aa43059 16. ? @ 0x00007f35aab92ac3 17. ? @ 0x00007f35aac24850 2025.09.09 15:06:48.404781 [ 3179 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:06:48.404817 [ 3184 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:06:48.453908 [ 3188 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:06:49.054786 [ 2761 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:06:49.409670 [ 2743 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:06:49.417557 [ 3235 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:06:49.458100 [ 2751 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:06:49.965687 [ 3339 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {b2866e3d-697f-407e-a02c-018043ee7457::202509_1_157_39}: 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, char const*&&) @ 0x000000001adfc17a 4. ./build_docker/./src/Common/MemoryTracker.cpp:187: MemoryTracker::injectFault() const @ 0x000000001adf8d1a 5. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:0: DB::MergePlainMergeTreeTask::finish() @ 0x000000002cc30a65 6. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:0: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000002cc2f47b 7. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000002c427f28 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000002c429675 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7eaf0 10. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001af8a79f 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 13. asan_thread_start(void*) @ 0x000000000aa43059 14. ? @ 0x00007f35aab92ac3 15. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:06:50.058763 [ 2821 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:06:50.423130 [ 2860 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:06:50.423243 [ 2848 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:06:50.459780 [ 2876 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:06:51.060635 [ 2940 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:06:51.426300 [ 2978 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:06:51.427029 [ 2989 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:06:51.540630 [ 2987 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:06:52.130632 [ 3038 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:06:52.231359 [ 20173 ] {} test_0473czib.mt (37fd3cf2-879f-4934-ac8d-662471988a31): dropAllData: got exception removing parts from disk, removing successfully removed parts from memory. 2025.09.09 15:06:52.239030 [ 20173 ] {} DatabaseCatalog: Cannot drop table test_0473czib.mt (37fd3cf2-879f-4934-ac8d-662471988a31). 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af819ed 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80746 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000263a174e 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002c47c445 8. ./contrib/llvm-project/libcxx/include/vector:547: DB::MergeTreeData::clearPartsFromFilesystem(std::vector, std::allocator>> const&, bool, std::unordered_set, std::equal_to, std::allocator>*) @ 0x000000002c47a78e 9. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::dropAllData() @ 0x000000002c4862d9 10. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::dropTableFinally(DB::DatabaseCatalog::TableMarkedAsDropped const&) @ 0x00000000286c7c77 11. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: void std::__function::__policy_invoker::__call_impl, std::allocator>>)::$_0, void ()>>(std::__function::__policy_storage const*) @ 0x00000000286d9744 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000263a3ea5 13. ./contrib/llvm-project/libcxx/include/future:0: std::packaged_task::operator()() @ 0x000000001bba33ac 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7eaf0 15. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001af8a79f 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 18. asan_thread_start(void*) @ 0x000000000aa43059 19. ? @ 0x00007f35aab92ac3 20. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:06:52.428243 [ 3062 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:06:52.431254 [ 3069 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:06:52.543985 [ 3102 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:06:53.132359 [ 3148 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:06:53.373065 [ 5356 ] {0bc0ecfd-755e-47b0-b37d-291fdf5d640f} ExternalDictionariesLoader: Could not load external dictionary 'b9456353-118f-4e69-ac1b-88d4f6a6e618', next update is scheduled at 2025-09-09 15:06:59: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=9, jobs=0): (while reading column key_column): (while reading from part /var/lib/clickhouse/store/cab/cabf9a66-80e2-4148-8335-3c53187f5a8a/all_1_1_0/ in table database_for_dict.table_for_dict (cabf9a66-80e2-4148-8335-3c53187f5a8a) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af80b71 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80746 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000266005a2 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000265fffb4 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:1197: ? @ 0x00000000265fd4e7 9. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:62: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x00000000265e6fbd 10. ./contrib/llvm-project/libcxx/include/future:1123: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x00000000265e7bb3 11. DB::ReadBuffer::next() @ 0x000000000b528aeb 12. ./src/IO/ReadBuffer.h:0: DB::CompressedReadBufferBase::readCompressedDataBlockForAsynchronous(unsigned long&, unsigned long&) @ 0x0000000027760e7f 13. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:110: DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x0000000027764c41 14. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:222: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x0000000027b97730 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 @ 0x0000000027aa00db 16. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:0: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x000000002c7b254b 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7eb79e 18. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:118: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7c9d8a 19. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x000000002c7e0473 20. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x000000002c7dbec3 21. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:0: DB::MergeTreeReadTask::read(DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002c82d05b 22. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:53: DB::MergeTreeInOrderSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&, DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002dea5374 23. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:0: DB::MergeTreeSelectProcessor::read() @ 0x000000002c8242f9 24. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000002de6d77a 25. ./build_docker/./src/Processors/ISource.cpp:0: DB::ISource::work() @ 0x000000002d3290a1 26. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 27. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 28. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 29. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 30. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 31. DB::FlatDictionary::loadData() @ 0x000000001b6725cb (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:06:53.390990 [ 20343 ] {4ae2ec5b-9c3f-41e3-8f5b-944755d24792} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=9, jobs=0): (while reading column key_column): (while reading from part /var/lib/clickhouse/store/cab/cabf9a66-80e2-4148-8335-3c53187f5a8a/all_1_1_0/ in table database_for_dict.table_for_dict (cabf9a66-80e2-4148-8335-3c53187f5a8a) located on disk default of type local, from mark 0 with max_rows_to_read = 1): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder): while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:60058) (comment: 01542_dictionary_load_exception_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af80b71 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80746 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000266005a2 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000265fffb4 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:1197: ? @ 0x00000000265fd4e7 9. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:62: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x00000000265e6fbd 10. ./contrib/llvm-project/libcxx/include/future:1123: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x00000000265e7bb3 11. DB::ReadBuffer::next() @ 0x000000000b528aeb 12. ./src/IO/ReadBuffer.h:0: DB::CompressedReadBufferBase::readCompressedDataBlockForAsynchronous(unsigned long&, unsigned long&) @ 0x0000000027760e7f 13. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:110: DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x0000000027764c41 14. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:222: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x0000000027b97730 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 @ 0x0000000027aa00db 16. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:0: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x000000002c7b254b 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7eb79e 18. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:118: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7c9d8a 19. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x000000002c7e0473 20. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x000000002c7dbec3 21. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:0: DB::MergeTreeReadTask::read(DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002c82d05b 22. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:53: DB::MergeTreeInOrderSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&, DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002dea5374 23. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:0: DB::MergeTreeSelectProcessor::read() @ 0x000000002c8242f9 24. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000002de6d77a 25. ./build_docker/./src/Processors/ISource.cpp:0: DB::ISource::work() @ 0x000000002d3290a1 26. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 27. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 28. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 29. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 30. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 31. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 2025.09.09 15:06:53.391482 [ 20350 ] {286a1bd1-07f8-4702-9dd2-7001518e908a} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=9, jobs=0): (while reading column key_column): (while reading from part /var/lib/clickhouse/store/cab/cabf9a66-80e2-4148-8335-3c53187f5a8a/all_1_1_0/ in table database_for_dict.table_for_dict (cabf9a66-80e2-4148-8335-3c53187f5a8a) located on disk default of type local, from mark 0 with max_rows_to_read = 1): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder): while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:60060) (comment: 01542_dictionary_load_exception_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af80b71 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80746 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000266005a2 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000265fffb4 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:1197: ? @ 0x00000000265fd4e7 9. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:62: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x00000000265e6fbd 10. ./contrib/llvm-project/libcxx/include/future:1123: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x00000000265e7bb3 11. DB::ReadBuffer::next() @ 0x000000000b528aeb 12. ./src/IO/ReadBuffer.h:0: DB::CompressedReadBufferBase::readCompressedDataBlockForAsynchronous(unsigned long&, unsigned long&) @ 0x0000000027760e7f 13. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:110: DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x0000000027764c41 14. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:222: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x0000000027b97730 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 @ 0x0000000027aa00db 16. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:0: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x000000002c7b254b 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7eb79e 18. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:118: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7c9d8a 19. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x000000002c7e0473 20. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x000000002c7dbec3 21. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:0: DB::MergeTreeReadTask::read(DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002c82d05b 22. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:53: DB::MergeTreeInOrderSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&, DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002dea5374 23. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:0: DB::MergeTreeSelectProcessor::read() @ 0x000000002c8242f9 24. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000002de6d77a 25. ./build_docker/./src/Processors/ISource.cpp:0: DB::ISource::work() @ 0x000000002d3290a1 26. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 27. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 28. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 29. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 30. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 31. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 2025.09.09 15:06:53.392211 [ 20397 ] {20fc9287-b011-4bda-99e5-c823184e682d} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=9, jobs=0): (while reading column key_column): (while reading from part /var/lib/clickhouse/store/cab/cabf9a66-80e2-4148-8335-3c53187f5a8a/all_1_1_0/ in table database_for_dict.table_for_dict (cabf9a66-80e2-4148-8335-3c53187f5a8a) located on disk default of type local, from mark 0 with max_rows_to_read = 1): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder): while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:60044) (comment: 01542_dictionary_load_exception_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af80b71 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80746 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000266005a2 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000265fffb4 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:1197: ? @ 0x00000000265fd4e7 9. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:62: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x00000000265e6fbd 10. ./contrib/llvm-project/libcxx/include/future:1123: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x00000000265e7bb3 11. DB::ReadBuffer::next() @ 0x000000000b528aeb 12. ./src/IO/ReadBuffer.h:0: DB::CompressedReadBufferBase::readCompressedDataBlockForAsynchronous(unsigned long&, unsigned long&) @ 0x0000000027760e7f 13. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:110: DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x0000000027764c41 14. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:222: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x0000000027b97730 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 @ 0x0000000027aa00db 16. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:0: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x000000002c7b254b 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7eb79e 18. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:118: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7c9d8a 19. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x000000002c7e0473 20. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x000000002c7dbec3 21. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:0: DB::MergeTreeReadTask::read(DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002c82d05b 22. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:53: DB::MergeTreeInOrderSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&, DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002dea5374 23. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:0: DB::MergeTreeSelectProcessor::read() @ 0x000000002c8242f9 24. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000002de6d77a 25. ./build_docker/./src/Processors/ISource.cpp:0: DB::ISource::work() @ 0x000000002d3290a1 26. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 27. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 28. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 29. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 30. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 31. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 2025.09.09 15:06:53.393950 [ 20343 ] {4ae2ec5b-9c3f-41e3-8f5b-944755d24792} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=9, jobs=0): (while reading column key_column): (while reading from part /var/lib/clickhouse/store/cab/cabf9a66-80e2-4148-8335-3c53187f5a8a/all_1_1_0/ in table database_for_dict.table_for_dict (cabf9a66-80e2-4148-8335-3c53187f5a8a) located on disk default of type local, from mark 0 with max_rows_to_read = 1): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder): while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af80b71 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80746 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000266005a2 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000265fffb4 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:1197: ? @ 0x00000000265fd4e7 9. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:62: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x00000000265e6fbd 10. ./contrib/llvm-project/libcxx/include/future:1123: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x00000000265e7bb3 11. DB::ReadBuffer::next() @ 0x000000000b528aeb 12. ./src/IO/ReadBuffer.h:0: DB::CompressedReadBufferBase::readCompressedDataBlockForAsynchronous(unsigned long&, unsigned long&) @ 0x0000000027760e7f 13. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:110: DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x0000000027764c41 14. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:222: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x0000000027b97730 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 @ 0x0000000027aa00db 16. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:0: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x000000002c7b254b 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7eb79e 18. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:118: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7c9d8a 19. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x000000002c7e0473 20. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x000000002c7dbec3 21. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:0: DB::MergeTreeReadTask::read(DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002c82d05b 22. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:53: DB::MergeTreeInOrderSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&, DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002dea5374 23. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:0: DB::MergeTreeSelectProcessor::read() @ 0x000000002c8242f9 24. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000002de6d77a 25. ./build_docker/./src/Processors/ISource.cpp:0: DB::ISource::work() @ 0x000000002d3290a1 26. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 27. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 28. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 29. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 30. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 31. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 2025.09.09 15:06:53.394098 [ 20338 ] {0bc0ecfd-755e-47b0-b37d-291fdf5d640f} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=9, jobs=0): (while reading column key_column): (while reading from part /var/lib/clickhouse/store/cab/cabf9a66-80e2-4148-8335-3c53187f5a8a/all_1_1_0/ in table database_for_dict.table_for_dict (cabf9a66-80e2-4148-8335-3c53187f5a8a) located on disk default of type local, from mark 0 with max_rows_to_read = 1): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder): while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:60040) (comment: 01542_dictionary_load_exception_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af80b71 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80746 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000266005a2 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000265fffb4 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:1197: ? @ 0x00000000265fd4e7 9. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:62: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x00000000265e6fbd 10. ./contrib/llvm-project/libcxx/include/future:1123: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x00000000265e7bb3 11. DB::ReadBuffer::next() @ 0x000000000b528aeb 12. ./src/IO/ReadBuffer.h:0: DB::CompressedReadBufferBase::readCompressedDataBlockForAsynchronous(unsigned long&, unsigned long&) @ 0x0000000027760e7f 13. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:110: DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x0000000027764c41 14. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:222: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x0000000027b97730 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 @ 0x0000000027aa00db 16. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:0: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x000000002c7b254b 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7eb79e 18. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:118: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7c9d8a 19. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x000000002c7e0473 20. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x000000002c7dbec3 21. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:0: DB::MergeTreeReadTask::read(DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002c82d05b 22. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:53: DB::MergeTreeInOrderSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&, DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002dea5374 23. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:0: DB::MergeTreeSelectProcessor::read() @ 0x000000002c8242f9 24. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000002de6d77a 25. ./build_docker/./src/Processors/ISource.cpp:0: DB::ISource::work() @ 0x000000002d3290a1 26. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 27. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 28. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 29. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 30. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 31. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 2025.09.09 15:06:53.394075 [ 20350 ] {286a1bd1-07f8-4702-9dd2-7001518e908a} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=9, jobs=0): (while reading column key_column): (while reading from part /var/lib/clickhouse/store/cab/cabf9a66-80e2-4148-8335-3c53187f5a8a/all_1_1_0/ in table database_for_dict.table_for_dict (cabf9a66-80e2-4148-8335-3c53187f5a8a) located on disk default of type local, from mark 0 with max_rows_to_read = 1): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder): while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af80b71 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80746 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000266005a2 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000265fffb4 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:1197: ? @ 0x00000000265fd4e7 9. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:62: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x00000000265e6fbd 10. ./contrib/llvm-project/libcxx/include/future:1123: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x00000000265e7bb3 11. DB::ReadBuffer::next() @ 0x000000000b528aeb 12. ./src/IO/ReadBuffer.h:0: DB::CompressedReadBufferBase::readCompressedDataBlockForAsynchronous(unsigned long&, unsigned long&) @ 0x0000000027760e7f 13. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:110: DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x0000000027764c41 14. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:222: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x0000000027b97730 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 @ 0x0000000027aa00db 16. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:0: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x000000002c7b254b 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7eb79e 18. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:118: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7c9d8a 19. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x000000002c7e0473 20. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x000000002c7dbec3 21. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:0: DB::MergeTreeReadTask::read(DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002c82d05b 22. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:53: DB::MergeTreeInOrderSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&, DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002dea5374 23. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:0: DB::MergeTreeSelectProcessor::read() @ 0x000000002c8242f9 24. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000002de6d77a 25. ./build_docker/./src/Processors/ISource.cpp:0: DB::ISource::work() @ 0x000000002d3290a1 26. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 27. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 28. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 29. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 30. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 31. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 2025.09.09 15:06:53.395247 [ 20397 ] {20fc9287-b011-4bda-99e5-c823184e682d} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=9, jobs=0): (while reading column key_column): (while reading from part /var/lib/clickhouse/store/cab/cabf9a66-80e2-4148-8335-3c53187f5a8a/all_1_1_0/ in table database_for_dict.table_for_dict (cabf9a66-80e2-4148-8335-3c53187f5a8a) located on disk default of type local, from mark 0 with max_rows_to_read = 1): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder): while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af80b71 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80746 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000266005a2 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000265fffb4 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:1197: ? @ 0x00000000265fd4e7 9. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:62: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x00000000265e6fbd 10. ./contrib/llvm-project/libcxx/include/future:1123: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x00000000265e7bb3 11. DB::ReadBuffer::next() @ 0x000000000b528aeb 12. ./src/IO/ReadBuffer.h:0: DB::CompressedReadBufferBase::readCompressedDataBlockForAsynchronous(unsigned long&, unsigned long&) @ 0x0000000027760e7f 13. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:110: DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x0000000027764c41 14. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:222: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x0000000027b97730 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 @ 0x0000000027aa00db 16. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:0: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x000000002c7b254b 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7eb79e 18. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:118: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7c9d8a 19. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x000000002c7e0473 20. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x000000002c7dbec3 21. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:0: DB::MergeTreeReadTask::read(DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002c82d05b 22. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:53: DB::MergeTreeInOrderSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&, DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002dea5374 23. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:0: DB::MergeTreeSelectProcessor::read() @ 0x000000002c8242f9 24. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000002de6d77a 25. ./build_docker/./src/Processors/ISource.cpp:0: DB::ISource::work() @ 0x000000002d3290a1 26. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 27. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 28. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 29. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 30. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 31. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 2025.09.09 15:06:53.397031 [ 20338 ] {0bc0ecfd-755e-47b0-b37d-291fdf5d640f} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=9, jobs=0): (while reading column key_column): (while reading from part /var/lib/clickhouse/store/cab/cabf9a66-80e2-4148-8335-3c53187f5a8a/all_1_1_0/ in table database_for_dict.table_for_dict (cabf9a66-80e2-4148-8335-3c53187f5a8a) located on disk default of type local, from mark 0 with max_rows_to_read = 1): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder): while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af80b71 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80746 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000266005a2 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000265fffb4 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:1197: ? @ 0x00000000265fd4e7 9. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:62: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x00000000265e6fbd 10. ./contrib/llvm-project/libcxx/include/future:1123: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x00000000265e7bb3 11. DB::ReadBuffer::next() @ 0x000000000b528aeb 12. ./src/IO/ReadBuffer.h:0: DB::CompressedReadBufferBase::readCompressedDataBlockForAsynchronous(unsigned long&, unsigned long&) @ 0x0000000027760e7f 13. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:110: DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x0000000027764c41 14. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:222: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x0000000027b97730 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 @ 0x0000000027aa00db 16. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:0: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x000000002c7b254b 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7eb79e 18. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:118: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7c9d8a 19. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x000000002c7e0473 20. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x000000002c7dbec3 21. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:0: DB::MergeTreeReadTask::read(DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002c82d05b 22. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:53: DB::MergeTreeInOrderSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&, DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002dea5374 23. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:0: DB::MergeTreeSelectProcessor::read() @ 0x000000002c8242f9 24. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000002de6d77a 25. ./build_docker/./src/Processors/ISource.cpp:0: DB::ISource::work() @ 0x000000002d3290a1 26. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 27. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 28. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 29. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 30. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 31. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 2025.09.09 15:06:53.430808 [ 3174 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:06:53.432879 [ 3161 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:06:53.545775 [ 3195 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:06:53.746393 [ 20355 ] {cd9838ab-0265-4c86-9c2b-e32fd08c0756} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=9, jobs=0): (while reading column key_column): (while reading from part /var/lib/clickhouse/store/cab/cabf9a66-80e2-4148-8335-3c53187f5a8a/all_1_1_0/ in table database_for_dict.table_for_dict (cabf9a66-80e2-4148-8335-3c53187f5a8a) located on disk default of type local, from mark 0 with max_rows_to_read = 1): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder): while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:60076) (comment: 01542_dictionary_load_exception_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af80b71 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80746 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000266005a2 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000265fffb4 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:1197: ? @ 0x00000000265fd4e7 9. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:62: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x00000000265e6fbd 10. ./contrib/llvm-project/libcxx/include/future:1123: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x00000000265e7bb3 11. DB::ReadBuffer::next() @ 0x000000000b528aeb 12. ./src/IO/ReadBuffer.h:0: DB::CompressedReadBufferBase::readCompressedDataBlockForAsynchronous(unsigned long&, unsigned long&) @ 0x0000000027760e7f 13. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:110: DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x0000000027764c41 14. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:222: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x0000000027b97730 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 @ 0x0000000027aa00db 16. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:0: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x000000002c7b254b 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7eb79e 18. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:118: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7c9d8a 19. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x000000002c7e0473 20. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x000000002c7dbec3 21. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:0: DB::MergeTreeReadTask::read(DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002c82d05b 22. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:53: DB::MergeTreeInOrderSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&, DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002dea5374 23. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:0: DB::MergeTreeSelectProcessor::read() @ 0x000000002c8242f9 24. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000002de6d77a 25. ./build_docker/./src/Processors/ISource.cpp:0: DB::ISource::work() @ 0x000000002d3290a1 26. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 27. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 28. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 29. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 30. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 31. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 2025.09.09 15:06:53.775612 [ 20355 ] {cd9838ab-0265-4c86-9c2b-e32fd08c0756} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=9, jobs=0): (while reading column key_column): (while reading from part /var/lib/clickhouse/store/cab/cabf9a66-80e2-4148-8335-3c53187f5a8a/all_1_1_0/ in table database_for_dict.table_for_dict (cabf9a66-80e2-4148-8335-3c53187f5a8a) located on disk default of type local, from mark 0 with max_rows_to_read = 1): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder): while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af80b71 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80746 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000266005a2 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000265fffb4 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:1197: ? @ 0x00000000265fd4e7 9. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:62: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x00000000265e6fbd 10. ./contrib/llvm-project/libcxx/include/future:1123: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x00000000265e7bb3 11. DB::ReadBuffer::next() @ 0x000000000b528aeb 12. ./src/IO/ReadBuffer.h:0: DB::CompressedReadBufferBase::readCompressedDataBlockForAsynchronous(unsigned long&, unsigned long&) @ 0x0000000027760e7f 13. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:110: DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x0000000027764c41 14. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:222: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x0000000027b97730 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 @ 0x0000000027aa00db 16. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:0: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x000000002c7b254b 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7eb79e 18. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:118: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7c9d8a 19. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x000000002c7e0473 20. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x000000002c7dbec3 21. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:0: DB::MergeTreeReadTask::read(DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002c82d05b 22. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:53: DB::MergeTreeInOrderSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&, DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002dea5374 23. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:0: DB::MergeTreeSelectProcessor::read() @ 0x000000002c8242f9 24. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000002de6d77a 25. ./build_docker/./src/Processors/ISource.cpp:0: DB::ISource::work() @ 0x000000002d3290a1 26. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 27. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 28. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 29. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 30. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 31. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 2025.09.09 15:06:53.788281 [ 20380 ] {aa452c58-66a1-4b12-aacb-ed80977656e0} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=9, jobs=0): (while reading column key_column): (while reading from part /var/lib/clickhouse/store/cab/cabf9a66-80e2-4148-8335-3c53187f5a8a/all_1_1_0/ in table database_for_dict.table_for_dict (cabf9a66-80e2-4148-8335-3c53187f5a8a) located on disk default of type local, from mark 0 with max_rows_to_read = 1): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder): while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:60180) (comment: 01542_dictionary_load_exception_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af80b71 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80746 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000266005a2 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000265fffb4 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:1197: ? @ 0x00000000265fd4e7 9. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:62: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x00000000265e6fbd 10. ./contrib/llvm-project/libcxx/include/future:1123: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x00000000265e7bb3 11. DB::ReadBuffer::next() @ 0x000000000b528aeb 12. ./src/IO/ReadBuffer.h:0: DB::CompressedReadBufferBase::readCompressedDataBlockForAsynchronous(unsigned long&, unsigned long&) @ 0x0000000027760e7f 13. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:110: DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x0000000027764c41 14. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:222: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x0000000027b97730 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 @ 0x0000000027aa00db 16. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:0: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x000000002c7b254b 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7eb79e 18. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:118: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7c9d8a 19. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x000000002c7e0473 20. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x000000002c7dbec3 21. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:0: DB::MergeTreeReadTask::read(DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002c82d05b 22. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:53: DB::MergeTreeInOrderSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&, DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002dea5374 23. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:0: DB::MergeTreeSelectProcessor::read() @ 0x000000002c8242f9 24. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000002de6d77a 25. ./build_docker/./src/Processors/ISource.cpp:0: DB::ISource::work() @ 0x000000002d3290a1 26. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 27. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 28. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 29. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 30. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 31. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 2025.09.09 15:06:53.793402 [ 20353 ] {f11536b6-bf74-4c80-94f4-7d4ea99125a2} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=9, jobs=0): (while reading column key_column): (while reading from part /var/lib/clickhouse/store/cab/cabf9a66-80e2-4148-8335-3c53187f5a8a/all_1_1_0/ in table database_for_dict.table_for_dict (cabf9a66-80e2-4148-8335-3c53187f5a8a) located on disk default of type local, from mark 0 with max_rows_to_read = 1): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder): while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:60138) (comment: 01542_dictionary_load_exception_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af80b71 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80746 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000266005a2 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000265fffb4 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:1197: ? @ 0x00000000265fd4e7 9. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:62: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x00000000265e6fbd 10. ./contrib/llvm-project/libcxx/include/future:1123: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x00000000265e7bb3 11. DB::ReadBuffer::next() @ 0x000000000b528aeb 12. ./src/IO/ReadBuffer.h:0: DB::CompressedReadBufferBase::readCompressedDataBlockForAsynchronous(unsigned long&, unsigned long&) @ 0x0000000027760e7f 13. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:110: DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x0000000027764c41 14. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:222: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x0000000027b97730 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 @ 0x0000000027aa00db 16. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:0: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x000000002c7b254b 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7eb79e 18. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:118: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7c9d8a 19. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x000000002c7e0473 20. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x000000002c7dbec3 21. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:0: DB::MergeTreeReadTask::read(DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002c82d05b 22. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:53: DB::MergeTreeInOrderSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&, DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002dea5374 23. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:0: DB::MergeTreeSelectProcessor::read() @ 0x000000002c8242f9 24. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000002de6d77a 25. ./build_docker/./src/Processors/ISource.cpp:0: DB::ISource::work() @ 0x000000002d3290a1 26. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 27. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 28. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 29. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 30. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 31. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 2025.09.09 15:06:53.798951 [ 20380 ] {aa452c58-66a1-4b12-aacb-ed80977656e0} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=9, jobs=0): (while reading column key_column): (while reading from part /var/lib/clickhouse/store/cab/cabf9a66-80e2-4148-8335-3c53187f5a8a/all_1_1_0/ in table database_for_dict.table_for_dict (cabf9a66-80e2-4148-8335-3c53187f5a8a) located on disk default of type local, from mark 0 with max_rows_to_read = 1): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder): while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af80b71 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80746 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000266005a2 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000265fffb4 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:1197: ? @ 0x00000000265fd4e7 9. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:62: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x00000000265e6fbd 10. ./contrib/llvm-project/libcxx/include/future:1123: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x00000000265e7bb3 11. DB::ReadBuffer::next() @ 0x000000000b528aeb 12. ./src/IO/ReadBuffer.h:0: DB::CompressedReadBufferBase::readCompressedDataBlockForAsynchronous(unsigned long&, unsigned long&) @ 0x0000000027760e7f 13. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:110: DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x0000000027764c41 14. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:222: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x0000000027b97730 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 @ 0x0000000027aa00db 16. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:0: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x000000002c7b254b 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7eb79e 18. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:118: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7c9d8a 19. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x000000002c7e0473 20. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x000000002c7dbec3 21. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:0: DB::MergeTreeReadTask::read(DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002c82d05b 22. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:53: DB::MergeTreeInOrderSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&, DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002dea5374 23. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:0: DB::MergeTreeSelectProcessor::read() @ 0x000000002c8242f9 24. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000002de6d77a 25. ./build_docker/./src/Processors/ISource.cpp:0: DB::ISource::work() @ 0x000000002d3290a1 26. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 27. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 28. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 29. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 30. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 31. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 2025.09.09 15:06:53.806302 [ 20353 ] {f11536b6-bf74-4c80-94f4-7d4ea99125a2} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=9, jobs=0): (while reading column key_column): (while reading from part /var/lib/clickhouse/store/cab/cabf9a66-80e2-4148-8335-3c53187f5a8a/all_1_1_0/ in table database_for_dict.table_for_dict (cabf9a66-80e2-4148-8335-3c53187f5a8a) located on disk default of type local, from mark 0 with max_rows_to_read = 1): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder): while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af80b71 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80746 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000266005a2 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000265fffb4 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:1197: ? @ 0x00000000265fd4e7 9. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:62: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x00000000265e6fbd 10. ./contrib/llvm-project/libcxx/include/future:1123: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x00000000265e7bb3 11. DB::ReadBuffer::next() @ 0x000000000b528aeb 12. ./src/IO/ReadBuffer.h:0: DB::CompressedReadBufferBase::readCompressedDataBlockForAsynchronous(unsigned long&, unsigned long&) @ 0x0000000027760e7f 13. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:110: DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x0000000027764c41 14. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:222: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x0000000027b97730 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 @ 0x0000000027aa00db 16. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:0: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x000000002c7b254b 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7eb79e 18. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:118: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7c9d8a 19. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x000000002c7e0473 20. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x000000002c7dbec3 21. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:0: DB::MergeTreeReadTask::read(DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002c82d05b 22. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:53: DB::MergeTreeInOrderSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&, DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002dea5374 23. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:0: DB::MergeTreeSelectProcessor::read() @ 0x000000002c8242f9 24. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000002de6d77a 25. ./build_docker/./src/Processors/ISource.cpp:0: DB::ISource::work() @ 0x000000002d3290a1 26. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 27. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 28. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 29. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 30. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 31. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 2025.09.09 15:06:53.815180 [ 2688 ] {fa62ecff-1113-453c-b703-57327974b4e8} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=9, jobs=0): (while reading column key_column): (while reading from part /var/lib/clickhouse/store/cab/cabf9a66-80e2-4148-8335-3c53187f5a8a/all_1_1_0/ in table database_for_dict.table_for_dict (cabf9a66-80e2-4148-8335-3c53187f5a8a) located on disk default of type local, from mark 0 with max_rows_to_read = 1): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder): while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:60134) (comment: 01542_dictionary_load_exception_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af80b71 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80746 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000266005a2 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000265fffb4 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:1197: ? @ 0x00000000265fd4e7 9. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:62: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x00000000265e6fbd 10. ./contrib/llvm-project/libcxx/include/future:1123: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x00000000265e7bb3 11. DB::ReadBuffer::next() @ 0x000000000b528aeb 12. ./src/IO/ReadBuffer.h:0: DB::CompressedReadBufferBase::readCompressedDataBlockForAsynchronous(unsigned long&, unsigned long&) @ 0x0000000027760e7f 13. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:110: DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x0000000027764c41 14. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:222: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x0000000027b97730 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 @ 0x0000000027aa00db 16. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:0: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x000000002c7b254b 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7eb79e 18. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:118: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7c9d8a 19. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x000000002c7e0473 20. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x000000002c7dbec3 21. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:0: DB::MergeTreeReadTask::read(DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002c82d05b 22. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:53: DB::MergeTreeInOrderSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&, DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002dea5374 23. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:0: DB::MergeTreeSelectProcessor::read() @ 0x000000002c8242f9 24. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000002de6d77a 25. ./build_docker/./src/Processors/ISource.cpp:0: DB::ISource::work() @ 0x000000002d3290a1 26. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 27. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 28. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 29. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 30. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 31. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 2025.09.09 15:06:53.816451 [ 20351 ] {417a5d07-d148-444b-b094-0af89b93c738} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=9, jobs=0): (while reading column key_column): (while reading from part /var/lib/clickhouse/store/cab/cabf9a66-80e2-4148-8335-3c53187f5a8a/all_1_1_0/ in table database_for_dict.table_for_dict (cabf9a66-80e2-4148-8335-3c53187f5a8a) located on disk default of type local, from mark 0 with max_rows_to_read = 1): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder): while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:60108) (comment: 01542_dictionary_load_exception_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af80b71 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80746 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000266005a2 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000265fffb4 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:1197: ? @ 0x00000000265fd4e7 9. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:62: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x00000000265e6fbd 10. ./contrib/llvm-project/libcxx/include/future:1123: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x00000000265e7bb3 11. DB::ReadBuffer::next() @ 0x000000000b528aeb 12. ./src/IO/ReadBuffer.h:0: DB::CompressedReadBufferBase::readCompressedDataBlockForAsynchronous(unsigned long&, unsigned long&) @ 0x0000000027760e7f 13. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:110: DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x0000000027764c41 14. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:222: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x0000000027b97730 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 @ 0x0000000027aa00db 16. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:0: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x000000002c7b254b 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7eb79e 18. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:118: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7c9d8a 19. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x000000002c7e0473 20. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x000000002c7dbec3 21. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:0: DB::MergeTreeReadTask::read(DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002c82d05b 22. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:53: DB::MergeTreeInOrderSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&, DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002dea5374 23. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:0: DB::MergeTreeSelectProcessor::read() @ 0x000000002c8242f9 24. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000002de6d77a 25. ./build_docker/./src/Processors/ISource.cpp:0: DB::ISource::work() @ 0x000000002d3290a1 26. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 27. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 28. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 29. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 30. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 31. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 2025.09.09 15:06:53.817091 [ 2688 ] {fa62ecff-1113-453c-b703-57327974b4e8} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=9, jobs=0): (while reading column key_column): (while reading from part /var/lib/clickhouse/store/cab/cabf9a66-80e2-4148-8335-3c53187f5a8a/all_1_1_0/ in table database_for_dict.table_for_dict (cabf9a66-80e2-4148-8335-3c53187f5a8a) located on disk default of type local, from mark 0 with max_rows_to_read = 1): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder): while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af80b71 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80746 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000266005a2 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000265fffb4 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:1197: ? @ 0x00000000265fd4e7 9. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:62: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x00000000265e6fbd 10. ./contrib/llvm-project/libcxx/include/future:1123: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x00000000265e7bb3 11. DB::ReadBuffer::next() @ 0x000000000b528aeb 12. ./src/IO/ReadBuffer.h:0: DB::CompressedReadBufferBase::readCompressedDataBlockForAsynchronous(unsigned long&, unsigned long&) @ 0x0000000027760e7f 13. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:110: DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x0000000027764c41 14. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:222: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x0000000027b97730 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 @ 0x0000000027aa00db 16. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:0: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x000000002c7b254b 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7eb79e 18. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:118: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7c9d8a 19. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x000000002c7e0473 20. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x000000002c7dbec3 21. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:0: DB::MergeTreeReadTask::read(DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002c82d05b 22. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:53: DB::MergeTreeInOrderSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&, DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002dea5374 23. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:0: DB::MergeTreeSelectProcessor::read() @ 0x000000002c8242f9 24. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000002de6d77a 25. ./build_docker/./src/Processors/ISource.cpp:0: DB::ISource::work() @ 0x000000002d3290a1 26. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 27. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 28. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 29. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 30. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 31. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 2025.09.09 15:06:53.824293 [ 3612 ] {ccfbab17-032e-4eff-b67f-3e8f1bc8ff2b} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=9, jobs=0): (while reading column key_column): (while reading from part /var/lib/clickhouse/store/cab/cabf9a66-80e2-4148-8335-3c53187f5a8a/all_1_1_0/ in table database_for_dict.table_for_dict (cabf9a66-80e2-4148-8335-3c53187f5a8a) located on disk default of type local, from mark 0 with max_rows_to_read = 1): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder): while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:60194) (comment: 01542_dictionary_load_exception_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af80b71 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80746 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000266005a2 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000265fffb4 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:1197: ? @ 0x00000000265fd4e7 9. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:62: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x00000000265e6fbd 10. ./contrib/llvm-project/libcxx/include/future:1123: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x00000000265e7bb3 11. DB::ReadBuffer::next() @ 0x000000000b528aeb 12. ./src/IO/ReadBuffer.h:0: DB::CompressedReadBufferBase::readCompressedDataBlockForAsynchronous(unsigned long&, unsigned long&) @ 0x0000000027760e7f 13. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:110: DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x0000000027764c41 14. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:222: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x0000000027b97730 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 @ 0x0000000027aa00db 16. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:0: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x000000002c7b254b 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7eb79e 18. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:118: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7c9d8a 19. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x000000002c7e0473 20. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x000000002c7dbec3 21. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:0: DB::MergeTreeReadTask::read(DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002c82d05b 22. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:53: DB::MergeTreeInOrderSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&, DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002dea5374 23. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:0: DB::MergeTreeSelectProcessor::read() @ 0x000000002c8242f9 24. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000002de6d77a 25. ./build_docker/./src/Processors/ISource.cpp:0: DB::ISource::work() @ 0x000000002d3290a1 26. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 27. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 28. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 29. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 30. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 31. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 2025.09.09 15:06:53.846675 [ 3612 ] {ccfbab17-032e-4eff-b67f-3e8f1bc8ff2b} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=9, jobs=0): (while reading column key_column): (while reading from part /var/lib/clickhouse/store/cab/cabf9a66-80e2-4148-8335-3c53187f5a8a/all_1_1_0/ in table database_for_dict.table_for_dict (cabf9a66-80e2-4148-8335-3c53187f5a8a) located on disk default of type local, from mark 0 with max_rows_to_read = 1): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder): while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af80b71 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80746 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000266005a2 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000265fffb4 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:1197: ? @ 0x00000000265fd4e7 9. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:62: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x00000000265e6fbd 10. ./contrib/llvm-project/libcxx/include/future:1123: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x00000000265e7bb3 11. DB::ReadBuffer::next() @ 0x000000000b528aeb 12. ./src/IO/ReadBuffer.h:0: DB::CompressedReadBufferBase::readCompressedDataBlockForAsynchronous(unsigned long&, unsigned long&) @ 0x0000000027760e7f 13. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:110: DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x0000000027764c41 14. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:222: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x0000000027b97730 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 @ 0x0000000027aa00db 16. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:0: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x000000002c7b254b 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7eb79e 18. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:118: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7c9d8a 19. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x000000002c7e0473 20. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x000000002c7dbec3 21. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:0: DB::MergeTreeReadTask::read(DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002c82d05b 22. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:53: DB::MergeTreeInOrderSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&, DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002dea5374 23. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:0: DB::MergeTreeSelectProcessor::read() @ 0x000000002c8242f9 24. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000002de6d77a 25. ./build_docker/./src/Processors/ISource.cpp:0: DB::ISource::work() @ 0x000000002d3290a1 26. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 27. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 28. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 29. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 30. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 31. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 2025.09.09 15:06:53.846738 [ 20351 ] {417a5d07-d148-444b-b094-0af89b93c738} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=9, jobs=0): (while reading column key_column): (while reading from part /var/lib/clickhouse/store/cab/cabf9a66-80e2-4148-8335-3c53187f5a8a/all_1_1_0/ in table database_for_dict.table_for_dict (cabf9a66-80e2-4148-8335-3c53187f5a8a) located on disk default of type local, from mark 0 with max_rows_to_read = 1): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder): while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af80b71 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80746 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000266005a2 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000265fffb4 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:1197: ? @ 0x00000000265fd4e7 9. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:62: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x00000000265e6fbd 10. ./contrib/llvm-project/libcxx/include/future:1123: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x00000000265e7bb3 11. DB::ReadBuffer::next() @ 0x000000000b528aeb 12. ./src/IO/ReadBuffer.h:0: DB::CompressedReadBufferBase::readCompressedDataBlockForAsynchronous(unsigned long&, unsigned long&) @ 0x0000000027760e7f 13. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:110: DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x0000000027764c41 14. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:222: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x0000000027b97730 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 @ 0x0000000027aa00db 16. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:0: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x000000002c7b254b 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7eb79e 18. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:118: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7c9d8a 19. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x000000002c7e0473 20. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x000000002c7dbec3 21. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:0: DB::MergeTreeReadTask::read(DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002c82d05b 22. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:53: DB::MergeTreeInOrderSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&, DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002dea5374 23. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:0: DB::MergeTreeSelectProcessor::read() @ 0x000000002c8242f9 24. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000002de6d77a 25. ./build_docker/./src/Processors/ISource.cpp:0: DB::ISource::work() @ 0x000000002d3290a1 26. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 27. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 28. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 29. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 30. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 31. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 2025.09.09 15:06:53.847173 [ 3722 ] {e1574e26-f0b4-4d68-b7f8-4562266b4f52} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=9, jobs=0): (while reading column key_column): (while reading from part /var/lib/clickhouse/store/cab/cabf9a66-80e2-4148-8335-3c53187f5a8a/all_1_1_0/ in table database_for_dict.table_for_dict (cabf9a66-80e2-4148-8335-3c53187f5a8a) located on disk default of type local, from mark 0 with max_rows_to_read = 1): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder): while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:60208) (comment: 01542_dictionary_load_exception_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af80b71 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80746 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000266005a2 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000265fffb4 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:1197: ? @ 0x00000000265fd4e7 9. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:62: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x00000000265e6fbd 10. ./contrib/llvm-project/libcxx/include/future:1123: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x00000000265e7bb3 11. DB::ReadBuffer::next() @ 0x000000000b528aeb 12. ./src/IO/ReadBuffer.h:0: DB::CompressedReadBufferBase::readCompressedDataBlockForAsynchronous(unsigned long&, unsigned long&) @ 0x0000000027760e7f 13. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:110: DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x0000000027764c41 14. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:222: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x0000000027b97730 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 @ 0x0000000027aa00db 16. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:0: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x000000002c7b254b 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7eb79e 18. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:118: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7c9d8a 19. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x000000002c7e0473 20. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x000000002c7dbec3 21. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:0: DB::MergeTreeReadTask::read(DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002c82d05b 22. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:53: DB::MergeTreeInOrderSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&, DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002dea5374 23. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:0: DB::MergeTreeSelectProcessor::read() @ 0x000000002c8242f9 24. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000002de6d77a 25. ./build_docker/./src/Processors/ISource.cpp:0: DB::ISource::work() @ 0x000000002d3290a1 26. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 27. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 28. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 29. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 30. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 31. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 2025.09.09 15:06:53.857013 [ 20379 ] {b24f0eb9-e016-4327-932a-e3a1eb060c14} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=9, jobs=0): (while reading column key_column): (while reading from part /var/lib/clickhouse/store/cab/cabf9a66-80e2-4148-8335-3c53187f5a8a/all_1_1_0/ in table database_for_dict.table_for_dict (cabf9a66-80e2-4148-8335-3c53187f5a8a) located on disk default of type local, from mark 0 with max_rows_to_read = 1): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder): while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:60152) (comment: 01542_dictionary_load_exception_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af80b71 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80746 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000266005a2 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000265fffb4 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:1197: ? @ 0x00000000265fd4e7 9. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:62: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x00000000265e6fbd 10. ./contrib/llvm-project/libcxx/include/future:1123: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x00000000265e7bb3 11. DB::ReadBuffer::next() @ 0x000000000b528aeb 12. ./src/IO/ReadBuffer.h:0: DB::CompressedReadBufferBase::readCompressedDataBlockForAsynchronous(unsigned long&, unsigned long&) @ 0x0000000027760e7f 13. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:110: DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x0000000027764c41 14. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:222: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x0000000027b97730 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 @ 0x0000000027aa00db 16. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:0: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x000000002c7b254b 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7eb79e 18. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:118: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7c9d8a 19. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x000000002c7e0473 20. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x000000002c7dbec3 21. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:0: DB::MergeTreeReadTask::read(DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002c82d05b 22. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:53: DB::MergeTreeInOrderSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&, DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002dea5374 23. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:0: DB::MergeTreeSelectProcessor::read() @ 0x000000002c8242f9 24. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000002de6d77a 25. ./build_docker/./src/Processors/ISource.cpp:0: DB::ISource::work() @ 0x000000002d3290a1 26. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 27. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 28. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 29. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 30. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 31. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 2025.09.09 15:06:53.858385 [ 3722 ] {e1574e26-f0b4-4d68-b7f8-4562266b4f52} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=9, jobs=0): (while reading column key_column): (while reading from part /var/lib/clickhouse/store/cab/cabf9a66-80e2-4148-8335-3c53187f5a8a/all_1_1_0/ in table database_for_dict.table_for_dict (cabf9a66-80e2-4148-8335-3c53187f5a8a) located on disk default of type local, from mark 0 with max_rows_to_read = 1): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder): while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af80b71 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80746 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000266005a2 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000265fffb4 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:1197: ? @ 0x00000000265fd4e7 9. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:62: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x00000000265e6fbd 10. ./contrib/llvm-project/libcxx/include/future:1123: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x00000000265e7bb3 11. DB::ReadBuffer::next() @ 0x000000000b528aeb 12. ./src/IO/ReadBuffer.h:0: DB::CompressedReadBufferBase::readCompressedDataBlockForAsynchronous(unsigned long&, unsigned long&) @ 0x0000000027760e7f 13. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:110: DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x0000000027764c41 14. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:222: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x0000000027b97730 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 @ 0x0000000027aa00db 16. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:0: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x000000002c7b254b 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7eb79e 18. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:118: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7c9d8a 19. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x000000002c7e0473 20. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x000000002c7dbec3 21. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:0: DB::MergeTreeReadTask::read(DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002c82d05b 22. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:53: DB::MergeTreeInOrderSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&, DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002dea5374 23. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:0: DB::MergeTreeSelectProcessor::read() @ 0x000000002c8242f9 24. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000002de6d77a 25. ./build_docker/./src/Processors/ISource.cpp:0: DB::ISource::work() @ 0x000000002d3290a1 26. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 27. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 28. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 29. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 30. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 31. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 2025.09.09 15:06:53.866763 [ 20379 ] {b24f0eb9-e016-4327-932a-e3a1eb060c14} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=9, jobs=0): (while reading column key_column): (while reading from part /var/lib/clickhouse/store/cab/cabf9a66-80e2-4148-8335-3c53187f5a8a/all_1_1_0/ in table database_for_dict.table_for_dict (cabf9a66-80e2-4148-8335-3c53187f5a8a) located on disk default of type local, from mark 0 with max_rows_to_read = 1): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder): while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af80b71 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80746 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000266005a2 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000265fffb4 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:1197: ? @ 0x00000000265fd4e7 9. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:62: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x00000000265e6fbd 10. ./contrib/llvm-project/libcxx/include/future:1123: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x00000000265e7bb3 11. DB::ReadBuffer::next() @ 0x000000000b528aeb 12. ./src/IO/ReadBuffer.h:0: DB::CompressedReadBufferBase::readCompressedDataBlockForAsynchronous(unsigned long&, unsigned long&) @ 0x0000000027760e7f 13. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:110: DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x0000000027764c41 14. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:222: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x0000000027b97730 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 @ 0x0000000027aa00db 16. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:0: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x000000002c7b254b 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7eb79e 18. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:118: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7c9d8a 19. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x000000002c7e0473 20. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x000000002c7dbec3 21. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:0: DB::MergeTreeReadTask::read(DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002c82d05b 22. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:53: DB::MergeTreeInOrderSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&, DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002dea5374 23. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:0: DB::MergeTreeSelectProcessor::read() @ 0x000000002c8242f9 24. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000002de6d77a 25. ./build_docker/./src/Processors/ISource.cpp:0: DB::ISource::work() @ 0x000000002d3290a1 26. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 27. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 28. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 29. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 30. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 31. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 2025.09.09 15:06:54.141741 [ 2737 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:06:54.435973 [ 3207 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:06:54.436524 [ 2736 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:06:54.452246 [ 3722 ] {2725bd0c-9270-4eb3-9f3b-ce32e5bb67f2} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=9, jobs=0): (while reading column key_column): (while reading from part /var/lib/clickhouse/store/cab/cabf9a66-80e2-4148-8335-3c53187f5a8a/all_1_1_0/ in table database_for_dict.table_for_dict (cabf9a66-80e2-4148-8335-3c53187f5a8a) located on disk default of type local, from mark 0 with max_rows_to_read = 1): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder): while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:60334) (comment: 01542_dictionary_load_exception_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af80b71 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80746 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000266005a2 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000265fffb4 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:1197: ? @ 0x00000000265fd4e7 9. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:62: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x00000000265e6fbd 10. ./contrib/llvm-project/libcxx/include/future:1123: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x00000000265e7bb3 11. DB::ReadBuffer::next() @ 0x000000000b528aeb 12. ./src/IO/ReadBuffer.h:0: DB::CompressedReadBufferBase::readCompressedDataBlockForAsynchronous(unsigned long&, unsigned long&) @ 0x0000000027760e7f 13. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:110: DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x0000000027764c41 14. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:222: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x0000000027b97730 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 @ 0x0000000027aa00db 16. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:0: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x000000002c7b254b 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7eb79e 18. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:118: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7c9d8a 19. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x000000002c7e0473 20. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x000000002c7dbec3 21. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:0: DB::MergeTreeReadTask::read(DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002c82d05b 22. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:53: DB::MergeTreeInOrderSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&, DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002dea5374 23. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:0: DB::MergeTreeSelectProcessor::read() @ 0x000000002c8242f9 24. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000002de6d77a 25. ./build_docker/./src/Processors/ISource.cpp:0: DB::ISource::work() @ 0x000000002d3290a1 26. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 27. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 28. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 29. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 30. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 31. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 2025.09.09 15:06:54.462078 [ 3722 ] {2725bd0c-9270-4eb3-9f3b-ce32e5bb67f2} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=9, jobs=0): (while reading column key_column): (while reading from part /var/lib/clickhouse/store/cab/cabf9a66-80e2-4148-8335-3c53187f5a8a/all_1_1_0/ in table database_for_dict.table_for_dict (cabf9a66-80e2-4148-8335-3c53187f5a8a) located on disk default of type local, from mark 0 with max_rows_to_read = 1): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder): while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af80b71 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80746 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000266005a2 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000265fffb4 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:1197: ? @ 0x00000000265fd4e7 9. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:62: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x00000000265e6fbd 10. ./contrib/llvm-project/libcxx/include/future:1123: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x00000000265e7bb3 11. DB::ReadBuffer::next() @ 0x000000000b528aeb 12. ./src/IO/ReadBuffer.h:0: DB::CompressedReadBufferBase::readCompressedDataBlockForAsynchronous(unsigned long&, unsigned long&) @ 0x0000000027760e7f 13. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:110: DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x0000000027764c41 14. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:222: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x0000000027b97730 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 @ 0x0000000027aa00db 16. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:0: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x000000002c7b254b 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7eb79e 18. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:118: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7c9d8a 19. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x000000002c7e0473 20. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x000000002c7dbec3 21. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:0: DB::MergeTreeReadTask::read(DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002c82d05b 22. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:53: DB::MergeTreeInOrderSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&, DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002dea5374 23. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:0: DB::MergeTreeSelectProcessor::read() @ 0x000000002c8242f9 24. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000002de6d77a 25. ./build_docker/./src/Processors/ISource.cpp:0: DB::ISource::work() @ 0x000000002d3290a1 26. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 27. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 28. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 29. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 30. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 31. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 2025.09.09 15:06:54.462360 [ 20397 ] {35689e3f-21ab-446c-a772-cbe5c4589a71} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=9, jobs=0): (while reading column key_column): (while reading from part /var/lib/clickhouse/store/cab/cabf9a66-80e2-4148-8335-3c53187f5a8a/all_1_1_0/ in table database_for_dict.table_for_dict (cabf9a66-80e2-4148-8335-3c53187f5a8a) located on disk default of type local, from mark 0 with max_rows_to_read = 1): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder): while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:60318) (comment: 01542_dictionary_load_exception_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af80b71 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80746 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000266005a2 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000265fffb4 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:1197: ? @ 0x00000000265fd4e7 9. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:62: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x00000000265e6fbd 10. ./contrib/llvm-project/libcxx/include/future:1123: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x00000000265e7bb3 11. DB::ReadBuffer::next() @ 0x000000000b528aeb 12. ./src/IO/ReadBuffer.h:0: DB::CompressedReadBufferBase::readCompressedDataBlockForAsynchronous(unsigned long&, unsigned long&) @ 0x0000000027760e7f 13. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:110: DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x0000000027764c41 14. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:222: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x0000000027b97730 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 @ 0x0000000027aa00db 16. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:0: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x000000002c7b254b 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7eb79e 18. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:118: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7c9d8a 19. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x000000002c7e0473 20. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x000000002c7dbec3 21. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:0: DB::MergeTreeReadTask::read(DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002c82d05b 22. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:53: DB::MergeTreeInOrderSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&, DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002dea5374 23. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:0: DB::MergeTreeSelectProcessor::read() @ 0x000000002c8242f9 24. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000002de6d77a 25. ./build_docker/./src/Processors/ISource.cpp:0: DB::ISource::work() @ 0x000000002d3290a1 26. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 27. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 28. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 29. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 30. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 31. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 2025.09.09 15:06:54.464815 [ 20397 ] {35689e3f-21ab-446c-a772-cbe5c4589a71} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=9, jobs=0): (while reading column key_column): (while reading from part /var/lib/clickhouse/store/cab/cabf9a66-80e2-4148-8335-3c53187f5a8a/all_1_1_0/ in table database_for_dict.table_for_dict (cabf9a66-80e2-4148-8335-3c53187f5a8a) located on disk default of type local, from mark 0 with max_rows_to_read = 1): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder): while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af80b71 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80746 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000266005a2 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000265fffb4 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:1197: ? @ 0x00000000265fd4e7 9. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:62: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x00000000265e6fbd 10. ./contrib/llvm-project/libcxx/include/future:1123: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x00000000265e7bb3 11. DB::ReadBuffer::next() @ 0x000000000b528aeb 12. ./src/IO/ReadBuffer.h:0: DB::CompressedReadBufferBase::readCompressedDataBlockForAsynchronous(unsigned long&, unsigned long&) @ 0x0000000027760e7f 13. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:110: DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x0000000027764c41 14. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:222: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x0000000027b97730 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 @ 0x0000000027aa00db 16. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:0: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x000000002c7b254b 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7eb79e 18. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:118: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7c9d8a 19. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x000000002c7e0473 20. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x000000002c7dbec3 21. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:0: DB::MergeTreeReadTask::read(DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002c82d05b 22. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:53: DB::MergeTreeInOrderSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&, DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002dea5374 23. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:0: DB::MergeTreeSelectProcessor::read() @ 0x000000002c8242f9 24. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000002de6d77a 25. ./build_docker/./src/Processors/ISource.cpp:0: DB::ISource::work() @ 0x000000002d3290a1 26. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 27. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 28. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 29. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 30. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 31. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 2025.09.09 15:06:54.472627 [ 3612 ] {ac8fc460-2225-41e3-bbdf-003b3a62480b} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=9, jobs=0): (while reading column key_column): (while reading from part /var/lib/clickhouse/store/cab/cabf9a66-80e2-4148-8335-3c53187f5a8a/all_1_1_0/ in table database_for_dict.table_for_dict (cabf9a66-80e2-4148-8335-3c53187f5a8a) located on disk default of type local, from mark 0 with max_rows_to_read = 1): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder): while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:60350) (comment: 01542_dictionary_load_exception_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af80b71 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80746 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000266005a2 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000265fffb4 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:1197: ? @ 0x00000000265fd4e7 9. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:62: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x00000000265e6fbd 10. ./contrib/llvm-project/libcxx/include/future:1123: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x00000000265e7bb3 11. DB::ReadBuffer::next() @ 0x000000000b528aeb 12. ./src/IO/ReadBuffer.h:0: DB::CompressedReadBufferBase::readCompressedDataBlockForAsynchronous(unsigned long&, unsigned long&) @ 0x0000000027760e7f 13. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:110: DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x0000000027764c41 14. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:222: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x0000000027b97730 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 @ 0x0000000027aa00db 16. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:0: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x000000002c7b254b 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7eb79e 18. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:118: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7c9d8a 19. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x000000002c7e0473 20. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x000000002c7dbec3 21. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:0: DB::MergeTreeReadTask::read(DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002c82d05b 22. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:53: DB::MergeTreeInOrderSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&, DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002dea5374 23. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:0: DB::MergeTreeSelectProcessor::read() @ 0x000000002c8242f9 24. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000002de6d77a 25. ./build_docker/./src/Processors/ISource.cpp:0: DB::ISource::work() @ 0x000000002d3290a1 26. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 27. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 28. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 29. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 30. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 31. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 2025.09.09 15:06:54.482134 [ 3612 ] {ac8fc460-2225-41e3-bbdf-003b3a62480b} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=9, jobs=0): (while reading column key_column): (while reading from part /var/lib/clickhouse/store/cab/cabf9a66-80e2-4148-8335-3c53187f5a8a/all_1_1_0/ in table database_for_dict.table_for_dict (cabf9a66-80e2-4148-8335-3c53187f5a8a) located on disk default of type local, from mark 0 with max_rows_to_read = 1): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder): while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af80b71 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80746 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000266005a2 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000265fffb4 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:1197: ? @ 0x00000000265fd4e7 9. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:62: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x00000000265e6fbd 10. ./contrib/llvm-project/libcxx/include/future:1123: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x00000000265e7bb3 11. DB::ReadBuffer::next() @ 0x000000000b528aeb 12. ./src/IO/ReadBuffer.h:0: DB::CompressedReadBufferBase::readCompressedDataBlockForAsynchronous(unsigned long&, unsigned long&) @ 0x0000000027760e7f 13. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:110: DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x0000000027764c41 14. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:222: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x0000000027b97730 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 @ 0x0000000027aa00db 16. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:0: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x000000002c7b254b 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7eb79e 18. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:118: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7c9d8a 19. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x000000002c7e0473 20. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x000000002c7dbec3 21. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:0: DB::MergeTreeReadTask::read(DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002c82d05b 22. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:53: DB::MergeTreeInOrderSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&, DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002dea5374 23. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:0: DB::MergeTreeSelectProcessor::read() @ 0x000000002c8242f9 24. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000002de6d77a 25. ./build_docker/./src/Processors/ISource.cpp:0: DB::ISource::work() @ 0x000000002d3290a1 26. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 27. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 28. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 29. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 30. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 31. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 2025.09.09 15:06:54.551609 [ 2762 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:06:54.595475 [ 20338 ] {455807cb-a988-4e83-b003-e3ed60eabc9d} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=9, jobs=0): (while reading column key_column): (while reading from part /var/lib/clickhouse/store/cab/cabf9a66-80e2-4148-8335-3c53187f5a8a/all_1_1_0/ in table database_for_dict.table_for_dict (cabf9a66-80e2-4148-8335-3c53187f5a8a) located on disk default of type local, from mark 0 with max_rows_to_read = 1): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder): while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:60368) (comment: 01542_dictionary_load_exception_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af80b71 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80746 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000266005a2 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000265fffb4 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:1197: ? @ 0x00000000265fd4e7 9. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:62: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x00000000265e6fbd 10. ./contrib/llvm-project/libcxx/include/future:1123: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x00000000265e7bb3 11. DB::ReadBuffer::next() @ 0x000000000b528aeb 12. ./src/IO/ReadBuffer.h:0: DB::CompressedReadBufferBase::readCompressedDataBlockForAsynchronous(unsigned long&, unsigned long&) @ 0x0000000027760e7f 13. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:110: DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x0000000027764c41 14. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:222: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x0000000027b97730 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 @ 0x0000000027aa00db 16. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:0: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x000000002c7b254b 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7eb79e 18. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:118: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7c9d8a 19. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x000000002c7e0473 20. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x000000002c7dbec3 21. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:0: DB::MergeTreeReadTask::read(DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002c82d05b 22. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:53: DB::MergeTreeInOrderSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&, DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002dea5374 23. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:0: DB::MergeTreeSelectProcessor::read() @ 0x000000002c8242f9 24. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000002de6d77a 25. ./build_docker/./src/Processors/ISource.cpp:0: DB::ISource::work() @ 0x000000002d3290a1 26. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 27. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 28. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 29. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 30. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 31. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 2025.09.09 15:06:54.693538 [ 20338 ] {455807cb-a988-4e83-b003-e3ed60eabc9d} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=9, jobs=0): (while reading column key_column): (while reading from part /var/lib/clickhouse/store/cab/cabf9a66-80e2-4148-8335-3c53187f5a8a/all_1_1_0/ in table database_for_dict.table_for_dict (cabf9a66-80e2-4148-8335-3c53187f5a8a) located on disk default of type local, from mark 0 with max_rows_to_read = 1): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder): while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af80b71 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80746 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000266005a2 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000265fffb4 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:1197: ? @ 0x00000000265fd4e7 9. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:62: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x00000000265e6fbd 10. ./contrib/llvm-project/libcxx/include/future:1123: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x00000000265e7bb3 11. DB::ReadBuffer::next() @ 0x000000000b528aeb 12. ./src/IO/ReadBuffer.h:0: DB::CompressedReadBufferBase::readCompressedDataBlockForAsynchronous(unsigned long&, unsigned long&) @ 0x0000000027760e7f 13. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:110: DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x0000000027764c41 14. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:222: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x0000000027b97730 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 @ 0x0000000027aa00db 16. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:0: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x000000002c7b254b 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7eb79e 18. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:118: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7c9d8a 19. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x000000002c7e0473 20. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x000000002c7dbec3 21. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:0: DB::MergeTreeReadTask::read(DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002c82d05b 22. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:53: DB::MergeTreeInOrderSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&, DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002dea5374 23. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:0: DB::MergeTreeSelectProcessor::read() @ 0x000000002c8242f9 24. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000002de6d77a 25. ./build_docker/./src/Processors/ISource.cpp:0: DB::ISource::work() @ 0x000000002d3290a1 26. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 27. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 28. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 29. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 30. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 31. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 2025.09.09 15:06:54.747103 [ 20379 ] {757341c6-c305-411e-acac-e5e7cc98e4e0} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=9, jobs=0): (while reading column key_column): (while reading from part /var/lib/clickhouse/store/cab/cabf9a66-80e2-4148-8335-3c53187f5a8a/all_1_1_0/ in table database_for_dict.table_for_dict (cabf9a66-80e2-4148-8335-3c53187f5a8a) located on disk default of type local, from mark 0 with max_rows_to_read = 1): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder): while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:60446) (comment: 01542_dictionary_load_exception_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af80b71 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80746 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000266005a2 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000265fffb4 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:1197: ? @ 0x00000000265fd4e7 9. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:62: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x00000000265e6fbd 10. ./contrib/llvm-project/libcxx/include/future:1123: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x00000000265e7bb3 11. DB::ReadBuffer::next() @ 0x000000000b528aeb 12. ./src/IO/ReadBuffer.h:0: DB::CompressedReadBufferBase::readCompressedDataBlockForAsynchronous(unsigned long&, unsigned long&) @ 0x0000000027760e7f 13. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:110: DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x0000000027764c41 14. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:222: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x0000000027b97730 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 @ 0x0000000027aa00db 16. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:0: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x000000002c7b254b 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7eb79e 18. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:118: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7c9d8a 19. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x000000002c7e0473 20. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x000000002c7dbec3 21. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:0: DB::MergeTreeReadTask::read(DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002c82d05b 22. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:53: DB::MergeTreeInOrderSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&, DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002dea5374 23. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:0: DB::MergeTreeSelectProcessor::read() @ 0x000000002c8242f9 24. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000002de6d77a 25. ./build_docker/./src/Processors/ISource.cpp:0: DB::ISource::work() @ 0x000000002d3290a1 26. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 27. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 28. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 29. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 30. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 31. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 2025.09.09 15:06:54.749462 [ 20379 ] {757341c6-c305-411e-acac-e5e7cc98e4e0} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=9, jobs=0): (while reading column key_column): (while reading from part /var/lib/clickhouse/store/cab/cabf9a66-80e2-4148-8335-3c53187f5a8a/all_1_1_0/ in table database_for_dict.table_for_dict (cabf9a66-80e2-4148-8335-3c53187f5a8a) located on disk default of type local, from mark 0 with max_rows_to_read = 1): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder): while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af80b71 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80746 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000266005a2 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000265fffb4 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:1197: ? @ 0x00000000265fd4e7 9. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:62: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x00000000265e6fbd 10. ./contrib/llvm-project/libcxx/include/future:1123: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x00000000265e7bb3 11. DB::ReadBuffer::next() @ 0x000000000b528aeb 12. ./src/IO/ReadBuffer.h:0: DB::CompressedReadBufferBase::readCompressedDataBlockForAsynchronous(unsigned long&, unsigned long&) @ 0x0000000027760e7f 13. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:110: DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x0000000027764c41 14. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:222: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x0000000027b97730 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 @ 0x0000000027aa00db 16. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:0: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x000000002c7b254b 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7eb79e 18. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:118: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7c9d8a 19. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x000000002c7e0473 20. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x000000002c7dbec3 21. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:0: DB::MergeTreeReadTask::read(DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002c82d05b 22. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:53: DB::MergeTreeInOrderSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&, DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002dea5374 23. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:0: DB::MergeTreeSelectProcessor::read() @ 0x000000002c8242f9 24. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000002de6d77a 25. ./build_docker/./src/Processors/ISource.cpp:0: DB::ISource::work() @ 0x000000002d3290a1 26. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 27. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 28. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 29. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 30. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 31. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 2025.09.09 15:06:54.766555 [ 20345 ] {9c004c13-4d0a-4d67-9e74-e9c24ede3189} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=9, jobs=0): (while reading column key_column): (while reading from part /var/lib/clickhouse/store/cab/cabf9a66-80e2-4148-8335-3c53187f5a8a/all_1_1_0/ in table database_for_dict.table_for_dict (cabf9a66-80e2-4148-8335-3c53187f5a8a) located on disk default of type local, from mark 0 with max_rows_to_read = 1): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder): while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:60450) (comment: 01542_dictionary_load_exception_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af80b71 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80746 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000266005a2 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000265fffb4 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:1197: ? @ 0x00000000265fd4e7 9. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:62: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x00000000265e6fbd 10. ./contrib/llvm-project/libcxx/include/future:1123: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x00000000265e7bb3 11. DB::ReadBuffer::next() @ 0x000000000b528aeb 12. ./src/IO/ReadBuffer.h:0: DB::CompressedReadBufferBase::readCompressedDataBlockForAsynchronous(unsigned long&, unsigned long&) @ 0x0000000027760e7f 13. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:110: DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x0000000027764c41 14. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:222: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x0000000027b97730 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 @ 0x0000000027aa00db 16. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:0: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x000000002c7b254b 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7eb79e 18. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:118: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7c9d8a 19. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x000000002c7e0473 20. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x000000002c7dbec3 21. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:0: DB::MergeTreeReadTask::read(DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002c82d05b 22. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:53: DB::MergeTreeInOrderSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&, DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002dea5374 23. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:0: DB::MergeTreeSelectProcessor::read() @ 0x000000002c8242f9 24. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000002de6d77a 25. ./build_docker/./src/Processors/ISource.cpp:0: DB::ISource::work() @ 0x000000002d3290a1 26. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 27. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 28. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 29. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 30. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 31. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 2025.09.09 15:06:54.776862 [ 20345 ] {9c004c13-4d0a-4d67-9e74-e9c24ede3189} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=9, jobs=0): (while reading column key_column): (while reading from part /var/lib/clickhouse/store/cab/cabf9a66-80e2-4148-8335-3c53187f5a8a/all_1_1_0/ in table database_for_dict.table_for_dict (cabf9a66-80e2-4148-8335-3c53187f5a8a) located on disk default of type local, from mark 0 with max_rows_to_read = 1): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder): while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af80b71 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80746 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000266005a2 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000265fffb4 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:1197: ? @ 0x00000000265fd4e7 9. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:62: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x00000000265e6fbd 10. ./contrib/llvm-project/libcxx/include/future:1123: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x00000000265e7bb3 11. DB::ReadBuffer::next() @ 0x000000000b528aeb 12. ./src/IO/ReadBuffer.h:0: DB::CompressedReadBufferBase::readCompressedDataBlockForAsynchronous(unsigned long&, unsigned long&) @ 0x0000000027760e7f 13. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:110: DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x0000000027764c41 14. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:222: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x0000000027b97730 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 @ 0x0000000027aa00db 16. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:0: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x000000002c7b254b 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7eb79e 18. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:118: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7c9d8a 19. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x000000002c7e0473 20. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x000000002c7dbec3 21. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:0: DB::MergeTreeReadTask::read(DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002c82d05b 22. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:53: DB::MergeTreeInOrderSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&, DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002dea5374 23. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:0: DB::MergeTreeSelectProcessor::read() @ 0x000000002c8242f9 24. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000002de6d77a 25. ./build_docker/./src/Processors/ISource.cpp:0: DB::ISource::work() @ 0x000000002d3290a1 26. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 27. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 28. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 29. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 30. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 31. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 2025.09.09 15:06:54.787307 [ 20380 ] {9f6636d1-6b80-4635-8946-9e04e46219c7} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=9, jobs=0): (while reading column key_column): (while reading from part /var/lib/clickhouse/store/cab/cabf9a66-80e2-4148-8335-3c53187f5a8a/all_1_1_0/ in table database_for_dict.table_for_dict (cabf9a66-80e2-4148-8335-3c53187f5a8a) located on disk default of type local, from mark 0 with max_rows_to_read = 1): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder): while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:60454) (comment: 01542_dictionary_load_exception_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af80b71 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80746 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000266005a2 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000265fffb4 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:1197: ? @ 0x00000000265fd4e7 9. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:62: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x00000000265e6fbd 10. ./contrib/llvm-project/libcxx/include/future:1123: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x00000000265e7bb3 11. DB::ReadBuffer::next() @ 0x000000000b528aeb 12. ./src/IO/ReadBuffer.h:0: DB::CompressedReadBufferBase::readCompressedDataBlockForAsynchronous(unsigned long&, unsigned long&) @ 0x0000000027760e7f 13. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:110: DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x0000000027764c41 14. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:222: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x0000000027b97730 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 @ 0x0000000027aa00db 16. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:0: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x000000002c7b254b 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7eb79e 18. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:118: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7c9d8a 19. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x000000002c7e0473 20. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x000000002c7dbec3 21. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:0: DB::MergeTreeReadTask::read(DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002c82d05b 22. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:53: DB::MergeTreeInOrderSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&, DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002dea5374 23. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:0: DB::MergeTreeSelectProcessor::read() @ 0x000000002c8242f9 24. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000002de6d77a 25. ./build_docker/./src/Processors/ISource.cpp:0: DB::ISource::work() @ 0x000000002d3290a1 26. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 27. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 28. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 29. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 30. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 31. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 2025.09.09 15:06:54.794417 [ 19252 ] {f3c1be58-7fea-4b5f-ab15-0ae03bce4140} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=9, jobs=0): (while reading column key_column): (while reading from part /var/lib/clickhouse/store/cab/cabf9a66-80e2-4148-8335-3c53187f5a8a/all_1_1_0/ in table database_for_dict.table_for_dict (cabf9a66-80e2-4148-8335-3c53187f5a8a) located on disk default of type local, from mark 0 with max_rows_to_read = 1): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder): while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:60460) (comment: 01542_dictionary_load_exception_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af80b71 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80746 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000266005a2 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000265fffb4 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:1197: ? @ 0x00000000265fd4e7 9. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:62: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x00000000265e6fbd 10. ./contrib/llvm-project/libcxx/include/future:1123: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x00000000265e7bb3 11. DB::ReadBuffer::next() @ 0x000000000b528aeb 12. ./src/IO/ReadBuffer.h:0: DB::CompressedReadBufferBase::readCompressedDataBlockForAsynchronous(unsigned long&, unsigned long&) @ 0x0000000027760e7f 13. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:110: DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x0000000027764c41 14. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:222: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x0000000027b97730 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 @ 0x0000000027aa00db 16. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:0: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x000000002c7b254b 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7eb79e 18. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:118: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7c9d8a 19. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x000000002c7e0473 20. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x000000002c7dbec3 21. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:0: DB::MergeTreeReadTask::read(DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002c82d05b 22. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:53: DB::MergeTreeInOrderSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&, DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002dea5374 23. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:0: DB::MergeTreeSelectProcessor::read() @ 0x000000002c8242f9 24. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000002de6d77a 25. ./build_docker/./src/Processors/ISource.cpp:0: DB::ISource::work() @ 0x000000002d3290a1 26. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 27. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 28. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 29. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 30. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 31. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 2025.09.09 15:06:54.798226 [ 19252 ] {f3c1be58-7fea-4b5f-ab15-0ae03bce4140} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=9, jobs=0): (while reading column key_column): (while reading from part /var/lib/clickhouse/store/cab/cabf9a66-80e2-4148-8335-3c53187f5a8a/all_1_1_0/ in table database_for_dict.table_for_dict (cabf9a66-80e2-4148-8335-3c53187f5a8a) located on disk default of type local, from mark 0 with max_rows_to_read = 1): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder): while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af80b71 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80746 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000266005a2 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000265fffb4 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:1197: ? @ 0x00000000265fd4e7 9. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:62: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x00000000265e6fbd 10. ./contrib/llvm-project/libcxx/include/future:1123: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x00000000265e7bb3 11. DB::ReadBuffer::next() @ 0x000000000b528aeb 12. ./src/IO/ReadBuffer.h:0: DB::CompressedReadBufferBase::readCompressedDataBlockForAsynchronous(unsigned long&, unsigned long&) @ 0x0000000027760e7f 13. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:110: DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x0000000027764c41 14. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:222: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x0000000027b97730 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 @ 0x0000000027aa00db 16. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:0: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x000000002c7b254b 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7eb79e 18. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:118: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7c9d8a 19. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x000000002c7e0473 20. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x000000002c7dbec3 21. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:0: DB::MergeTreeReadTask::read(DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002c82d05b 22. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:53: DB::MergeTreeInOrderSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&, DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002dea5374 23. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:0: DB::MergeTreeSelectProcessor::read() @ 0x000000002c8242f9 24. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000002de6d77a 25. ./build_docker/./src/Processors/ISource.cpp:0: DB::ISource::work() @ 0x000000002d3290a1 26. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 27. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 28. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 29. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 30. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 31. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 2025.09.09 15:06:54.805499 [ 20353 ] {d3ea351e-20c2-444e-bdbe-34bdedc7ee8c} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=9, jobs=0): (while reading column key_column): (while reading from part /var/lib/clickhouse/store/cab/cabf9a66-80e2-4148-8335-3c53187f5a8a/all_1_1_0/ in table database_for_dict.table_for_dict (cabf9a66-80e2-4148-8335-3c53187f5a8a) located on disk default of type local, from mark 0 with max_rows_to_read = 1): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder): while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:60416) (comment: 01542_dictionary_load_exception_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af80b71 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80746 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000266005a2 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000265fffb4 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:1197: ? @ 0x00000000265fd4e7 9. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:62: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x00000000265e6fbd 10. ./contrib/llvm-project/libcxx/include/future:1123: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x00000000265e7bb3 11. DB::ReadBuffer::next() @ 0x000000000b528aeb 12. ./src/IO/ReadBuffer.h:0: DB::CompressedReadBufferBase::readCompressedDataBlockForAsynchronous(unsigned long&, unsigned long&) @ 0x0000000027760e7f 13. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:110: DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x0000000027764c41 14. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:222: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x0000000027b97730 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 @ 0x0000000027aa00db 16. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:0: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x000000002c7b254b 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7eb79e 18. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:118: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7c9d8a 19. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x000000002c7e0473 20. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x000000002c7dbec3 21. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:0: DB::MergeTreeReadTask::read(DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002c82d05b 22. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:53: DB::MergeTreeInOrderSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&, DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002dea5374 23. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:0: DB::MergeTreeSelectProcessor::read() @ 0x000000002c8242f9 24. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000002de6d77a 25. ./build_docker/./src/Processors/ISource.cpp:0: DB::ISource::work() @ 0x000000002d3290a1 26. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 27. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 28. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 29. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 30. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 31. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 2025.09.09 15:06:54.807638 [ 20353 ] {d3ea351e-20c2-444e-bdbe-34bdedc7ee8c} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=9, jobs=0): (while reading column key_column): (while reading from part /var/lib/clickhouse/store/cab/cabf9a66-80e2-4148-8335-3c53187f5a8a/all_1_1_0/ in table database_for_dict.table_for_dict (cabf9a66-80e2-4148-8335-3c53187f5a8a) located on disk default of type local, from mark 0 with max_rows_to_read = 1): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder): while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af80b71 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80746 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000266005a2 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000265fffb4 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:1197: ? @ 0x00000000265fd4e7 9. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:62: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x00000000265e6fbd 10. ./contrib/llvm-project/libcxx/include/future:1123: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x00000000265e7bb3 11. DB::ReadBuffer::next() @ 0x000000000b528aeb 12. ./src/IO/ReadBuffer.h:0: DB::CompressedReadBufferBase::readCompressedDataBlockForAsynchronous(unsigned long&, unsigned long&) @ 0x0000000027760e7f 13. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:110: DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x0000000027764c41 14. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:222: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x0000000027b97730 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 @ 0x0000000027aa00db 16. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:0: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x000000002c7b254b 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7eb79e 18. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:118: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7c9d8a 19. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x000000002c7e0473 20. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x000000002c7dbec3 21. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:0: DB::MergeTreeReadTask::read(DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002c82d05b 22. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:53: DB::MergeTreeInOrderSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&, DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002dea5374 23. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:0: DB::MergeTreeSelectProcessor::read() @ 0x000000002c8242f9 24. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000002de6d77a 25. ./build_docker/./src/Processors/ISource.cpp:0: DB::ISource::work() @ 0x000000002d3290a1 26. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 27. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 28. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 29. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 30. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 31. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 2025.09.09 15:06:54.830383 [ 20380 ] {9f6636d1-6b80-4635-8946-9e04e46219c7} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=9, jobs=0): (while reading column key_column): (while reading from part /var/lib/clickhouse/store/cab/cabf9a66-80e2-4148-8335-3c53187f5a8a/all_1_1_0/ in table database_for_dict.table_for_dict (cabf9a66-80e2-4148-8335-3c53187f5a8a) located on disk default of type local, from mark 0 with max_rows_to_read = 1): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder): while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af80b71 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80746 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000266005a2 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000265fffb4 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:1197: ? @ 0x00000000265fd4e7 9. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:62: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x00000000265e6fbd 10. ./contrib/llvm-project/libcxx/include/future:1123: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x00000000265e7bb3 11. DB::ReadBuffer::next() @ 0x000000000b528aeb 12. ./src/IO/ReadBuffer.h:0: DB::CompressedReadBufferBase::readCompressedDataBlockForAsynchronous(unsigned long&, unsigned long&) @ 0x0000000027760e7f 13. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:110: DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x0000000027764c41 14. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:222: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x0000000027b97730 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 @ 0x0000000027aa00db 16. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:0: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x000000002c7b254b 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7eb79e 18. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:118: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7c9d8a 19. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x000000002c7e0473 20. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x000000002c7dbec3 21. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:0: DB::MergeTreeReadTask::read(DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002c82d05b 22. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:53: DB::MergeTreeInOrderSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&, DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002dea5374 23. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:0: DB::MergeTreeSelectProcessor::read() @ 0x000000002c8242f9 24. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000002de6d77a 25. ./build_docker/./src/Processors/ISource.cpp:0: DB::ISource::work() @ 0x000000002d3290a1 26. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 27. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 28. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 29. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 30. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 31. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 2025.09.09 15:06:54.833664 [ 20355 ] {b664430c-75f1-476f-b7b6-56f5063ecce3} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=9, jobs=0): (while reading column key_column): (while reading from part /var/lib/clickhouse/store/cab/cabf9a66-80e2-4148-8335-3c53187f5a8a/all_1_1_0/ in table database_for_dict.table_for_dict (cabf9a66-80e2-4148-8335-3c53187f5a8a) located on disk default of type local, from mark 0 with max_rows_to_read = 1): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder): while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:60432) (comment: 01542_dictionary_load_exception_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af80b71 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80746 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000266005a2 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000265fffb4 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:1197: ? @ 0x00000000265fd4e7 9. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:62: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x00000000265e6fbd 10. ./contrib/llvm-project/libcxx/include/future:1123: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x00000000265e7bb3 11. DB::ReadBuffer::next() @ 0x000000000b528aeb 12. ./src/IO/ReadBuffer.h:0: DB::CompressedReadBufferBase::readCompressedDataBlockForAsynchronous(unsigned long&, unsigned long&) @ 0x0000000027760e7f 13. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:110: DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x0000000027764c41 14. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:222: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x0000000027b97730 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 @ 0x0000000027aa00db 16. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:0: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x000000002c7b254b 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7eb79e 18. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:118: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7c9d8a 19. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x000000002c7e0473 20. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x000000002c7dbec3 21. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:0: DB::MergeTreeReadTask::read(DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002c82d05b 22. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:53: DB::MergeTreeInOrderSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&, DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002dea5374 23. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:0: DB::MergeTreeSelectProcessor::read() @ 0x000000002c8242f9 24. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000002de6d77a 25. ./build_docker/./src/Processors/ISource.cpp:0: DB::ISource::work() @ 0x000000002d3290a1 26. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 27. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 28. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 29. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 30. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 31. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 2025.09.09 15:06:54.846656 [ 20355 ] {b664430c-75f1-476f-b7b6-56f5063ecce3} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=9, jobs=0): (while reading column key_column): (while reading from part /var/lib/clickhouse/store/cab/cabf9a66-80e2-4148-8335-3c53187f5a8a/all_1_1_0/ in table database_for_dict.table_for_dict (cabf9a66-80e2-4148-8335-3c53187f5a8a) located on disk default of type local, from mark 0 with max_rows_to_read = 1): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder): while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af80b71 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80746 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000266005a2 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000265fffb4 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:1197: ? @ 0x00000000265fd4e7 9. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:62: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x00000000265e6fbd 10. ./contrib/llvm-project/libcxx/include/future:1123: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x00000000265e7bb3 11. DB::ReadBuffer::next() @ 0x000000000b528aeb 12. ./src/IO/ReadBuffer.h:0: DB::CompressedReadBufferBase::readCompressedDataBlockForAsynchronous(unsigned long&, unsigned long&) @ 0x0000000027760e7f 13. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:110: DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x0000000027764c41 14. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:222: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x0000000027b97730 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 @ 0x0000000027aa00db 16. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:0: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x000000002c7b254b 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7eb79e 18. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:118: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7c9d8a 19. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x000000002c7e0473 20. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x000000002c7dbec3 21. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:0: DB::MergeTreeReadTask::read(DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002c82d05b 22. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:53: DB::MergeTreeInOrderSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&, DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002dea5374 23. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:0: DB::MergeTreeSelectProcessor::read() @ 0x000000002c8242f9 24. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000002de6d77a 25. ./build_docker/./src/Processors/ISource.cpp:0: DB::ISource::work() @ 0x000000002d3290a1 26. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 27. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 28. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 29. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 30. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 31. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 2025.09.09 15:06:54.858229 [ 20397 ] {806ec8b5-edf6-41f9-a39a-8167f2b56141} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=9, jobs=0): (while reading column key_column): (while reading from part /var/lib/clickhouse/store/cab/cabf9a66-80e2-4148-8335-3c53187f5a8a/all_1_1_0/ in table database_for_dict.table_for_dict (cabf9a66-80e2-4148-8335-3c53187f5a8a) located on disk default of type local, from mark 0 with max_rows_to_read = 1): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder): while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:60470) (comment: 01542_dictionary_load_exception_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af80b71 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80746 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000266005a2 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000265fffb4 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:1197: ? @ 0x00000000265fd4e7 9. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:62: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x00000000265e6fbd 10. ./contrib/llvm-project/libcxx/include/future:1123: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x00000000265e7bb3 11. DB::ReadBuffer::next() @ 0x000000000b528aeb 12. ./src/IO/ReadBuffer.h:0: DB::CompressedReadBufferBase::readCompressedDataBlockForAsynchronous(unsigned long&, unsigned long&) @ 0x0000000027760e7f 13. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:110: DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x0000000027764c41 14. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:222: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x0000000027b97730 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 @ 0x0000000027aa00db 16. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:0: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x000000002c7b254b 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7eb79e 18. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:118: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7c9d8a 19. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x000000002c7e0473 20. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x000000002c7dbec3 21. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:0: DB::MergeTreeReadTask::read(DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002c82d05b 22. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:53: DB::MergeTreeInOrderSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&, DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002dea5374 23. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:0: DB::MergeTreeSelectProcessor::read() @ 0x000000002c8242f9 24. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000002de6d77a 25. ./build_docker/./src/Processors/ISource.cpp:0: DB::ISource::work() @ 0x000000002d3290a1 26. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 27. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 28. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 29. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 30. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 31. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 2025.09.09 15:06:54.869945 [ 20397 ] {806ec8b5-edf6-41f9-a39a-8167f2b56141} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=9, jobs=0): (while reading column key_column): (while reading from part /var/lib/clickhouse/store/cab/cabf9a66-80e2-4148-8335-3c53187f5a8a/all_1_1_0/ in table database_for_dict.table_for_dict (cabf9a66-80e2-4148-8335-3c53187f5a8a) located on disk default of type local, from mark 0 with max_rows_to_read = 1): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder): while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af80b71 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80746 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000266005a2 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000265fffb4 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:1197: ? @ 0x00000000265fd4e7 9. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:62: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x00000000265e6fbd 10. ./contrib/llvm-project/libcxx/include/future:1123: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x00000000265e7bb3 11. DB::ReadBuffer::next() @ 0x000000000b528aeb 12. ./src/IO/ReadBuffer.h:0: DB::CompressedReadBufferBase::readCompressedDataBlockForAsynchronous(unsigned long&, unsigned long&) @ 0x0000000027760e7f 13. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:110: DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x0000000027764c41 14. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:222: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x0000000027b97730 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 @ 0x0000000027aa00db 16. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:0: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x000000002c7b254b 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7eb79e 18. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:118: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7c9d8a 19. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x000000002c7e0473 20. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x000000002c7dbec3 21. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:0: DB::MergeTreeReadTask::read(DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002c82d05b 22. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:53: DB::MergeTreeInOrderSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&, DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002dea5374 23. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:0: DB::MergeTreeSelectProcessor::read() @ 0x000000002c8242f9 24. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000002de6d77a 25. ./build_docker/./src/Processors/ISource.cpp:0: DB::ISource::work() @ 0x000000002d3290a1 26. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 27. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 28. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 29. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 30. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 31. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 2025.09.09 15:06:55.146080 [ 2818 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:06:55.491100 [ 2805 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:06:55.491194 [ 2831 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:06:55.595664 [ 2825 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:06:55.637548 [ 3612 ] {48071ab4-e2c0-4bcd-a138-1fb9de3c3bae} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=9, jobs=0): (while reading column key_column): (while reading from part /var/lib/clickhouse/store/cab/cabf9a66-80e2-4148-8335-3c53187f5a8a/all_1_1_0/ in table database_for_dict.table_for_dict (cabf9a66-80e2-4148-8335-3c53187f5a8a) located on disk default of type local, from mark 0 with max_rows_to_read = 1): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder): while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:60496) (comment: 01542_dictionary_load_exception_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af80b71 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80746 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000266005a2 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000265fffb4 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:1197: ? @ 0x00000000265fd4e7 9. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:62: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x00000000265e6fbd 10. ./contrib/llvm-project/libcxx/include/future:1123: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x00000000265e7bb3 11. DB::ReadBuffer::next() @ 0x000000000b528aeb 12. ./src/IO/ReadBuffer.h:0: DB::CompressedReadBufferBase::readCompressedDataBlockForAsynchronous(unsigned long&, unsigned long&) @ 0x0000000027760e7f 13. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:110: DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x0000000027764c41 14. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:222: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x0000000027b97730 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 @ 0x0000000027aa00db 16. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:0: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x000000002c7b254b 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7eb79e 18. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:118: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7c9d8a 19. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x000000002c7e0473 20. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x000000002c7dbec3 21. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:0: DB::MergeTreeReadTask::read(DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002c82d05b 22. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:53: DB::MergeTreeInOrderSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&, DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002dea5374 23. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:0: DB::MergeTreeSelectProcessor::read() @ 0x000000002c8242f9 24. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000002de6d77a 25. ./build_docker/./src/Processors/ISource.cpp:0: DB::ISource::work() @ 0x000000002d3290a1 26. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 27. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 28. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 29. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 30. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 31. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 2025.09.09 15:06:55.649173 [ 3612 ] {48071ab4-e2c0-4bcd-a138-1fb9de3c3bae} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=9, jobs=0): (while reading column key_column): (while reading from part /var/lib/clickhouse/store/cab/cabf9a66-80e2-4148-8335-3c53187f5a8a/all_1_1_0/ in table database_for_dict.table_for_dict (cabf9a66-80e2-4148-8335-3c53187f5a8a) located on disk default of type local, from mark 0 with max_rows_to_read = 1): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder): while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af80b71 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80746 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000266005a2 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000265fffb4 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:1197: ? @ 0x00000000265fd4e7 9. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:62: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x00000000265e6fbd 10. ./contrib/llvm-project/libcxx/include/future:1123: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x00000000265e7bb3 11. DB::ReadBuffer::next() @ 0x000000000b528aeb 12. ./src/IO/ReadBuffer.h:0: DB::CompressedReadBufferBase::readCompressedDataBlockForAsynchronous(unsigned long&, unsigned long&) @ 0x0000000027760e7f 13. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:110: DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x0000000027764c41 14. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:222: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x0000000027b97730 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 @ 0x0000000027aa00db 16. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:0: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x000000002c7b254b 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7eb79e 18. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:118: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7c9d8a 19. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x000000002c7e0473 20. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x000000002c7dbec3 21. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:0: DB::MergeTreeReadTask::read(DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002c82d05b 22. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:53: DB::MergeTreeInOrderSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&, DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002dea5374 23. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:0: DB::MergeTreeSelectProcessor::read() @ 0x000000002c8242f9 24. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000002de6d77a 25. ./build_docker/./src/Processors/ISource.cpp:0: DB::ISource::work() @ 0x000000002d3290a1 26. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 27. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 28. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 29. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 30. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 31. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 2025.09.09 15:06:55.821213 [ 20338 ] {7f0a8386-0cea-48b2-a281-bb97a329f4f2} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=9, jobs=0): (while reading column key_column): (while reading from part /var/lib/clickhouse/store/cab/cabf9a66-80e2-4148-8335-3c53187f5a8a/all_1_1_0/ in table database_for_dict.table_for_dict (cabf9a66-80e2-4148-8335-3c53187f5a8a) located on disk default of type local, from mark 0 with max_rows_to_read = 1): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder): while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:60526) (comment: 01542_dictionary_load_exception_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af80b71 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80746 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000266005a2 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000265fffb4 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:1197: ? @ 0x00000000265fd4e7 9. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:62: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x00000000265e6fbd 10. ./contrib/llvm-project/libcxx/include/future:1123: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x00000000265e7bb3 11. DB::ReadBuffer::next() @ 0x000000000b528aeb 12. ./src/IO/ReadBuffer.h:0: DB::CompressedReadBufferBase::readCompressedDataBlockForAsynchronous(unsigned long&, unsigned long&) @ 0x0000000027760e7f 13. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:110: DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x0000000027764c41 14. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:222: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x0000000027b97730 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 @ 0x0000000027aa00db 16. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:0: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x000000002c7b254b 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7eb79e 18. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:118: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7c9d8a 19. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x000000002c7e0473 20. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x000000002c7dbec3 21. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:0: DB::MergeTreeReadTask::read(DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002c82d05b 22. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:53: DB::MergeTreeInOrderSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&, DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002dea5374 23. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:0: DB::MergeTreeSelectProcessor::read() @ 0x000000002c8242f9 24. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000002de6d77a 25. ./build_docker/./src/Processors/ISource.cpp:0: DB::ISource::work() @ 0x000000002d3290a1 26. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 27. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 28. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 29. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 30. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 31. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 2025.09.09 15:06:55.821525 [ 2688 ] {6222b6c4-eb33-4731-923b-18c3e6bed422} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=9, jobs=0): (while reading column key_column): (while reading from part /var/lib/clickhouse/store/cab/cabf9a66-80e2-4148-8335-3c53187f5a8a/all_1_1_0/ in table database_for_dict.table_for_dict (cabf9a66-80e2-4148-8335-3c53187f5a8a) located on disk default of type local, from mark 0 with max_rows_to_read = 1): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder): while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:60520) (comment: 01542_dictionary_load_exception_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af80b71 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80746 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000266005a2 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000265fffb4 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:1197: ? @ 0x00000000265fd4e7 9. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:62: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x00000000265e6fbd 10. ./contrib/llvm-project/libcxx/include/future:1123: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x00000000265e7bb3 11. DB::ReadBuffer::next() @ 0x000000000b528aeb 12. ./src/IO/ReadBuffer.h:0: DB::CompressedReadBufferBase::readCompressedDataBlockForAsynchronous(unsigned long&, unsigned long&) @ 0x0000000027760e7f 13. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:110: DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x0000000027764c41 14. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:222: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x0000000027b97730 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 @ 0x0000000027aa00db 16. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:0: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x000000002c7b254b 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7eb79e 18. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:118: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7c9d8a 19. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x000000002c7e0473 20. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x000000002c7dbec3 21. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:0: DB::MergeTreeReadTask::read(DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002c82d05b 22. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:53: DB::MergeTreeInOrderSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&, DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002dea5374 23. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:0: DB::MergeTreeSelectProcessor::read() @ 0x000000002c8242f9 24. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000002de6d77a 25. ./build_docker/./src/Processors/ISource.cpp:0: DB::ISource::work() @ 0x000000002d3290a1 26. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 27. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 28. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 29. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 30. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 31. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 2025.09.09 15:06:55.830928 [ 2688 ] {6222b6c4-eb33-4731-923b-18c3e6bed422} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=9, jobs=0): (while reading column key_column): (while reading from part /var/lib/clickhouse/store/cab/cabf9a66-80e2-4148-8335-3c53187f5a8a/all_1_1_0/ in table database_for_dict.table_for_dict (cabf9a66-80e2-4148-8335-3c53187f5a8a) located on disk default of type local, from mark 0 with max_rows_to_read = 1): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder): while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af80b71 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80746 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000266005a2 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000265fffb4 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:1197: ? @ 0x00000000265fd4e7 9. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:62: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x00000000265e6fbd 10. ./contrib/llvm-project/libcxx/include/future:1123: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x00000000265e7bb3 11. DB::ReadBuffer::next() @ 0x000000000b528aeb 12. ./src/IO/ReadBuffer.h:0: DB::CompressedReadBufferBase::readCompressedDataBlockForAsynchronous(unsigned long&, unsigned long&) @ 0x0000000027760e7f 13. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:110: DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x0000000027764c41 14. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:222: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x0000000027b97730 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 @ 0x0000000027aa00db 16. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:0: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x000000002c7b254b 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7eb79e 18. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:118: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7c9d8a 19. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x000000002c7e0473 20. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x000000002c7dbec3 21. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:0: DB::MergeTreeReadTask::read(DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002c82d05b 22. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:53: DB::MergeTreeInOrderSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&, DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002dea5374 23. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:0: DB::MergeTreeSelectProcessor::read() @ 0x000000002c8242f9 24. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000002de6d77a 25. ./build_docker/./src/Processors/ISource.cpp:0: DB::ISource::work() @ 0x000000002d3290a1 26. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 27. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 28. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 29. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 30. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 31. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 2025.09.09 15:06:55.846761 [ 20338 ] {7f0a8386-0cea-48b2-a281-bb97a329f4f2} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=9, jobs=0): (while reading column key_column): (while reading from part /var/lib/clickhouse/store/cab/cabf9a66-80e2-4148-8335-3c53187f5a8a/all_1_1_0/ in table database_for_dict.table_for_dict (cabf9a66-80e2-4148-8335-3c53187f5a8a) located on disk default of type local, from mark 0 with max_rows_to_read = 1): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder): while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af80b71 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80746 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000266005a2 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000265fffb4 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:1197: ? @ 0x00000000265fd4e7 9. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:62: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x00000000265e6fbd 10. ./contrib/llvm-project/libcxx/include/future:1123: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x00000000265e7bb3 11. DB::ReadBuffer::next() @ 0x000000000b528aeb 12. ./src/IO/ReadBuffer.h:0: DB::CompressedReadBufferBase::readCompressedDataBlockForAsynchronous(unsigned long&, unsigned long&) @ 0x0000000027760e7f 13. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:110: DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x0000000027764c41 14. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:222: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x0000000027b97730 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 @ 0x0000000027aa00db 16. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:0: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x000000002c7b254b 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7eb79e 18. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:118: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7c9d8a 19. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x000000002c7e0473 20. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x000000002c7dbec3 21. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:0: DB::MergeTreeReadTask::read(DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002c82d05b 22. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:53: DB::MergeTreeInOrderSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&, DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002dea5374 23. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:0: DB::MergeTreeSelectProcessor::read() @ 0x000000002c8242f9 24. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000002de6d77a 25. ./build_docker/./src/Processors/ISource.cpp:0: DB::ISource::work() @ 0x000000002d3290a1 26. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 27. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 28. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 29. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 30. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 31. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 2025.09.09 15:06:56.037861 [ 20343 ] {8758ff98-8780-421a-a2d1-447a21161f42} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=9, jobs=0): (while reading column key_column): (while reading from part /var/lib/clickhouse/store/cab/cabf9a66-80e2-4148-8335-3c53187f5a8a/all_1_1_0/ in table database_for_dict.table_for_dict (cabf9a66-80e2-4148-8335-3c53187f5a8a) located on disk default of type local, from mark 0 with max_rows_to_read = 1): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder): while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:60540) (comment: 01542_dictionary_load_exception_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af80b71 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80746 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000266005a2 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000265fffb4 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:1197: ? @ 0x00000000265fd4e7 9. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:62: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x00000000265e6fbd 10. ./contrib/llvm-project/libcxx/include/future:1123: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x00000000265e7bb3 11. DB::ReadBuffer::next() @ 0x000000000b528aeb 12. ./src/IO/ReadBuffer.h:0: DB::CompressedReadBufferBase::readCompressedDataBlockForAsynchronous(unsigned long&, unsigned long&) @ 0x0000000027760e7f 13. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:110: DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x0000000027764c41 14. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:222: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x0000000027b97730 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 @ 0x0000000027aa00db 16. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:0: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x000000002c7b254b 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7eb79e 18. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:118: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7c9d8a 19. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x000000002c7e0473 20. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x000000002c7dbec3 21. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:0: DB::MergeTreeReadTask::read(DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002c82d05b 22. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:53: DB::MergeTreeInOrderSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&, DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002dea5374 23. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:0: DB::MergeTreeSelectProcessor::read() @ 0x000000002c8242f9 24. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000002de6d77a 25. ./build_docker/./src/Processors/ISource.cpp:0: DB::ISource::work() @ 0x000000002d3290a1 26. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 27. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 28. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 29. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 30. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 31. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 2025.09.09 15:06:56.040138 [ 20343 ] {8758ff98-8780-421a-a2d1-447a21161f42} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=9, jobs=0): (while reading column key_column): (while reading from part /var/lib/clickhouse/store/cab/cabf9a66-80e2-4148-8335-3c53187f5a8a/all_1_1_0/ in table database_for_dict.table_for_dict (cabf9a66-80e2-4148-8335-3c53187f5a8a) located on disk default of type local, from mark 0 with max_rows_to_read = 1): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder): while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af80b71 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80746 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000266005a2 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000265fffb4 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:1197: ? @ 0x00000000265fd4e7 9. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:62: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x00000000265e6fbd 10. ./contrib/llvm-project/libcxx/include/future:1123: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x00000000265e7bb3 11. DB::ReadBuffer::next() @ 0x000000000b528aeb 12. ./src/IO/ReadBuffer.h:0: DB::CompressedReadBufferBase::readCompressedDataBlockForAsynchronous(unsigned long&, unsigned long&) @ 0x0000000027760e7f 13. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:110: DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x0000000027764c41 14. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:222: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x0000000027b97730 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 @ 0x0000000027aa00db 16. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:0: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x000000002c7b254b 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7eb79e 18. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:118: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7c9d8a 19. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x000000002c7e0473 20. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x000000002c7dbec3 21. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:0: DB::MergeTreeReadTask::read(DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002c82d05b 22. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:53: DB::MergeTreeInOrderSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&, DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002dea5374 23. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:0: DB::MergeTreeSelectProcessor::read() @ 0x000000002c8242f9 24. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000002de6d77a 25. ./build_docker/./src/Processors/ISource.cpp:0: DB::ISource::work() @ 0x000000002d3290a1 26. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 27. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 28. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 29. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 30. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 31. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 2025.09.09 15:06:56.103663 [ 20379 ] {cc51dbdb-490b-4a48-bf68-c57d69b00efa} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=9, jobs=0): (while reading column key_column): (while reading from part /var/lib/clickhouse/store/cab/cabf9a66-80e2-4148-8335-3c53187f5a8a/all_1_1_0/ in table database_for_dict.table_for_dict (cabf9a66-80e2-4148-8335-3c53187f5a8a) located on disk default of type local, from mark 0 with max_rows_to_read = 1): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder): while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:60594) (comment: 01542_dictionary_load_exception_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af80b71 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80746 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000266005a2 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000265fffb4 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:1197: ? @ 0x00000000265fd4e7 9. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:62: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x00000000265e6fbd 10. ./contrib/llvm-project/libcxx/include/future:1123: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x00000000265e7bb3 11. DB::ReadBuffer::next() @ 0x000000000b528aeb 12. ./src/IO/ReadBuffer.h:0: DB::CompressedReadBufferBase::readCompressedDataBlockForAsynchronous(unsigned long&, unsigned long&) @ 0x0000000027760e7f 13. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:110: DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x0000000027764c41 14. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:222: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x0000000027b97730 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 @ 0x0000000027aa00db 16. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:0: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x000000002c7b254b 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7eb79e 18. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:118: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7c9d8a 19. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x000000002c7e0473 20. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x000000002c7dbec3 21. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:0: DB::MergeTreeReadTask::read(DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002c82d05b 22. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:53: DB::MergeTreeInOrderSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&, DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002dea5374 23. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:0: DB::MergeTreeSelectProcessor::read() @ 0x000000002c8242f9 24. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000002de6d77a 25. ./build_docker/./src/Processors/ISource.cpp:0: DB::ISource::work() @ 0x000000002d3290a1 26. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 27. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 28. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 29. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 30. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 31. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 2025.09.09 15:06:56.108228 [ 20379 ] {cc51dbdb-490b-4a48-bf68-c57d69b00efa} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=9, jobs=0): (while reading column key_column): (while reading from part /var/lib/clickhouse/store/cab/cabf9a66-80e2-4148-8335-3c53187f5a8a/all_1_1_0/ in table database_for_dict.table_for_dict (cabf9a66-80e2-4148-8335-3c53187f5a8a) located on disk default of type local, from mark 0 with max_rows_to_read = 1): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder): while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af80b71 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80746 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000266005a2 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000265fffb4 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:1197: ? @ 0x00000000265fd4e7 9. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:62: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x00000000265e6fbd 10. ./contrib/llvm-project/libcxx/include/future:1123: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x00000000265e7bb3 11. DB::ReadBuffer::next() @ 0x000000000b528aeb 12. ./src/IO/ReadBuffer.h:0: DB::CompressedReadBufferBase::readCompressedDataBlockForAsynchronous(unsigned long&, unsigned long&) @ 0x0000000027760e7f 13. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:110: DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x0000000027764c41 14. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:222: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x0000000027b97730 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 @ 0x0000000027aa00db 16. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:0: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x000000002c7b254b 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7eb79e 18. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:118: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7c9d8a 19. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x000000002c7e0473 20. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x000000002c7dbec3 21. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:0: DB::MergeTreeReadTask::read(DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002c82d05b 22. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:53: DB::MergeTreeInOrderSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&, DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002dea5374 23. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:0: DB::MergeTreeSelectProcessor::read() @ 0x000000002c8242f9 24. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000002de6d77a 25. ./build_docker/./src/Processors/ISource.cpp:0: DB::ISource::work() @ 0x000000002d3290a1 26. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 27. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 28. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 29. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 30. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 31. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 2025.09.09 15:06:56.118263 [ 20397 ] {ca58d94f-561c-4a9b-814a-ad1af2e0cf2b} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=9, jobs=0): (while reading column key_column): (while reading from part /var/lib/clickhouse/store/cab/cabf9a66-80e2-4148-8335-3c53187f5a8a/all_1_1_0/ in table database_for_dict.table_for_dict (cabf9a66-80e2-4148-8335-3c53187f5a8a) located on disk default of type local, from mark 0 with max_rows_to_read = 1): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder): while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:60538) (comment: 01542_dictionary_load_exception_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af80b71 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80746 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000266005a2 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000265fffb4 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:1197: ? @ 0x00000000265fd4e7 9. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:62: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x00000000265e6fbd 10. ./contrib/llvm-project/libcxx/include/future:1123: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x00000000265e7bb3 11. DB::ReadBuffer::next() @ 0x000000000b528aeb 12. ./src/IO/ReadBuffer.h:0: DB::CompressedReadBufferBase::readCompressedDataBlockForAsynchronous(unsigned long&, unsigned long&) @ 0x0000000027760e7f 13. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:110: DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x0000000027764c41 14. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:222: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x0000000027b97730 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 @ 0x0000000027aa00db 16. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:0: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x000000002c7b254b 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7eb79e 18. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:118: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7c9d8a 19. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x000000002c7e0473 20. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x000000002c7dbec3 21. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:0: DB::MergeTreeReadTask::read(DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002c82d05b 22. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:53: DB::MergeTreeInOrderSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&, DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002dea5374 23. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:0: DB::MergeTreeSelectProcessor::read() @ 0x000000002c8242f9 24. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000002de6d77a 25. ./build_docker/./src/Processors/ISource.cpp:0: DB::ISource::work() @ 0x000000002d3290a1 26. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 27. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 28. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 29. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 30. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 31. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 2025.09.09 15:06:56.118787 [ 20351 ] {dc7774e7-b758-4b4a-ab2e-206e6e32254c} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=9, jobs=0): (while reading column key_column): (while reading from part /var/lib/clickhouse/store/cab/cabf9a66-80e2-4148-8335-3c53187f5a8a/all_1_1_0/ in table database_for_dict.table_for_dict (cabf9a66-80e2-4148-8335-3c53187f5a8a) located on disk default of type local, from mark 0 with max_rows_to_read = 1): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder): while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:60570) (comment: 01542_dictionary_load_exception_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af80b71 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80746 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000266005a2 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000265fffb4 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:1197: ? @ 0x00000000265fd4e7 9. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:62: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x00000000265e6fbd 10. ./contrib/llvm-project/libcxx/include/future:1123: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x00000000265e7bb3 11. DB::ReadBuffer::next() @ 0x000000000b528aeb 12. ./src/IO/ReadBuffer.h:0: DB::CompressedReadBufferBase::readCompressedDataBlockForAsynchronous(unsigned long&, unsigned long&) @ 0x0000000027760e7f 13. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:110: DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x0000000027764c41 14. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:222: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x0000000027b97730 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 @ 0x0000000027aa00db 16. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:0: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x000000002c7b254b 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7eb79e 18. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:118: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7c9d8a 19. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x000000002c7e0473 20. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x000000002c7dbec3 21. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:0: DB::MergeTreeReadTask::read(DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002c82d05b 22. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:53: DB::MergeTreeInOrderSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&, DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002dea5374 23. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:0: DB::MergeTreeSelectProcessor::read() @ 0x000000002c8242f9 24. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000002de6d77a 25. ./build_docker/./src/Processors/ISource.cpp:0: DB::ISource::work() @ 0x000000002d3290a1 26. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 27. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 28. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 29. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 30. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 31. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 2025.09.09 15:06:56.121131 [ 20397 ] {ca58d94f-561c-4a9b-814a-ad1af2e0cf2b} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=9, jobs=0): (while reading column key_column): (while reading from part /var/lib/clickhouse/store/cab/cabf9a66-80e2-4148-8335-3c53187f5a8a/all_1_1_0/ in table database_for_dict.table_for_dict (cabf9a66-80e2-4148-8335-3c53187f5a8a) located on disk default of type local, from mark 0 with max_rows_to_read = 1): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder): while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af80b71 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80746 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000266005a2 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000265fffb4 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:1197: ? @ 0x00000000265fd4e7 9. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:62: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x00000000265e6fbd 10. ./contrib/llvm-project/libcxx/include/future:1123: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x00000000265e7bb3 11. DB::ReadBuffer::next() @ 0x000000000b528aeb 12. ./src/IO/ReadBuffer.h:0: DB::CompressedReadBufferBase::readCompressedDataBlockForAsynchronous(unsigned long&, unsigned long&) @ 0x0000000027760e7f 13. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:110: DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x0000000027764c41 14. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:222: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x0000000027b97730 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 @ 0x0000000027aa00db 16. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:0: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x000000002c7b254b 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7eb79e 18. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:118: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7c9d8a 19. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x000000002c7e0473 20. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x000000002c7dbec3 21. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:0: DB::MergeTreeReadTask::read(DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002c82d05b 22. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:53: DB::MergeTreeInOrderSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&, DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002dea5374 23. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:0: DB::MergeTreeSelectProcessor::read() @ 0x000000002c8242f9 24. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000002de6d77a 25. ./build_docker/./src/Processors/ISource.cpp:0: DB::ISource::work() @ 0x000000002d3290a1 26. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 27. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 28. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 29. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 30. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 31. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 2025.09.09 15:06:56.126285 [ 20351 ] {dc7774e7-b758-4b4a-ab2e-206e6e32254c} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=9, jobs=0): (while reading column key_column): (while reading from part /var/lib/clickhouse/store/cab/cabf9a66-80e2-4148-8335-3c53187f5a8a/all_1_1_0/ in table database_for_dict.table_for_dict (cabf9a66-80e2-4148-8335-3c53187f5a8a) located on disk default of type local, from mark 0 with max_rows_to_read = 1): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder): while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af80b71 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80746 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000266005a2 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000265fffb4 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:1197: ? @ 0x00000000265fd4e7 9. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:62: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x00000000265e6fbd 10. ./contrib/llvm-project/libcxx/include/future:1123: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x00000000265e7bb3 11. DB::ReadBuffer::next() @ 0x000000000b528aeb 12. ./src/IO/ReadBuffer.h:0: DB::CompressedReadBufferBase::readCompressedDataBlockForAsynchronous(unsigned long&, unsigned long&) @ 0x0000000027760e7f 13. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:110: DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x0000000027764c41 14. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:222: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x0000000027b97730 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 @ 0x0000000027aa00db 16. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:0: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x000000002c7b254b 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7eb79e 18. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:118: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7c9d8a 19. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x000000002c7e0473 20. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x000000002c7dbec3 21. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:0: DB::MergeTreeReadTask::read(DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002c82d05b 22. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:53: DB::MergeTreeInOrderSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&, DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002dea5374 23. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:0: DB::MergeTreeSelectProcessor::read() @ 0x000000002c8242f9 24. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000002de6d77a 25. ./build_docker/./src/Processors/ISource.cpp:0: DB::ISource::work() @ 0x000000002d3290a1 26. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 27. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 28. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 29. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 30. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 31. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 2025.09.09 15:06:56.130946 [ 20345 ] {3746ed9c-480a-4ba2-a8c8-1c8e38ee5bc4} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=9, jobs=0): (while reading column key_column): (while reading from part /var/lib/clickhouse/store/cab/cabf9a66-80e2-4148-8335-3c53187f5a8a/all_1_1_0/ in table database_for_dict.table_for_dict (cabf9a66-80e2-4148-8335-3c53187f5a8a) located on disk default of type local, from mark 0 with max_rows_to_read = 1): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder): while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:60610) (comment: 01542_dictionary_load_exception_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af80b71 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80746 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000266005a2 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000265fffb4 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:1197: ? @ 0x00000000265fd4e7 9. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:62: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x00000000265e6fbd 10. ./contrib/llvm-project/libcxx/include/future:1123: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x00000000265e7bb3 11. DB::ReadBuffer::next() @ 0x000000000b528aeb 12. ./src/IO/ReadBuffer.h:0: DB::CompressedReadBufferBase::readCompressedDataBlockForAsynchronous(unsigned long&, unsigned long&) @ 0x0000000027760e7f 13. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:110: DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x0000000027764c41 14. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:222: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x0000000027b97730 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 @ 0x0000000027aa00db 16. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:0: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x000000002c7b254b 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7eb79e 18. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:118: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7c9d8a 19. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x000000002c7e0473 20. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x000000002c7dbec3 21. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:0: DB::MergeTreeReadTask::read(DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002c82d05b 22. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:53: DB::MergeTreeInOrderSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&, DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002dea5374 23. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:0: DB::MergeTreeSelectProcessor::read() @ 0x000000002c8242f9 24. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000002de6d77a 25. ./build_docker/./src/Processors/ISource.cpp:0: DB::ISource::work() @ 0x000000002d3290a1 26. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 27. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 28. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 29. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 30. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 31. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 2025.09.09 15:06:56.133007 [ 20345 ] {3746ed9c-480a-4ba2-a8c8-1c8e38ee5bc4} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=9, jobs=0): (while reading column key_column): (while reading from part /var/lib/clickhouse/store/cab/cabf9a66-80e2-4148-8335-3c53187f5a8a/all_1_1_0/ in table database_for_dict.table_for_dict (cabf9a66-80e2-4148-8335-3c53187f5a8a) located on disk default of type local, from mark 0 with max_rows_to_read = 1): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder): while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af80b71 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80746 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000266005a2 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000265fffb4 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:1197: ? @ 0x00000000265fd4e7 9. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:62: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x00000000265e6fbd 10. ./contrib/llvm-project/libcxx/include/future:1123: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x00000000265e7bb3 11. DB::ReadBuffer::next() @ 0x000000000b528aeb 12. ./src/IO/ReadBuffer.h:0: DB::CompressedReadBufferBase::readCompressedDataBlockForAsynchronous(unsigned long&, unsigned long&) @ 0x0000000027760e7f 13. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:110: DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x0000000027764c41 14. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:222: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x0000000027b97730 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 @ 0x0000000027aa00db 16. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:0: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x000000002c7b254b 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7eb79e 18. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:118: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7c9d8a 19. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x000000002c7e0473 20. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x000000002c7dbec3 21. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:0: DB::MergeTreeReadTask::read(DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002c82d05b 22. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:53: DB::MergeTreeInOrderSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&, DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002dea5374 23. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:0: DB::MergeTreeSelectProcessor::read() @ 0x000000002c8242f9 24. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000002de6d77a 25. ./build_docker/./src/Processors/ISource.cpp:0: DB::ISource::work() @ 0x000000002d3290a1 26. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 27. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 28. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 29. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 30. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 31. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 2025.09.09 15:06:56.134755 [ 19252 ] {94fd93d5-e7ef-4590-b659-70ee5acd5fe1} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=9, jobs=0): (while reading column key_column): (while reading from part /var/lib/clickhouse/store/cab/cabf9a66-80e2-4148-8335-3c53187f5a8a/all_1_1_0/ in table database_for_dict.table_for_dict (cabf9a66-80e2-4148-8335-3c53187f5a8a) located on disk default of type local, from mark 0 with max_rows_to_read = 1): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder): while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:60632) (comment: 01542_dictionary_load_exception_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af80b71 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80746 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000266005a2 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000265fffb4 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:1197: ? @ 0x00000000265fd4e7 9. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:62: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x00000000265e6fbd 10. ./contrib/llvm-project/libcxx/include/future:1123: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x00000000265e7bb3 11. DB::ReadBuffer::next() @ 0x000000000b528aeb 12. ./src/IO/ReadBuffer.h:0: DB::CompressedReadBufferBase::readCompressedDataBlockForAsynchronous(unsigned long&, unsigned long&) @ 0x0000000027760e7f 13. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:110: DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x0000000027764c41 14. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:222: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x0000000027b97730 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 @ 0x0000000027aa00db 16. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:0: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x000000002c7b254b 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7eb79e 18. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:118: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7c9d8a 19. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x000000002c7e0473 20. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x000000002c7dbec3 21. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:0: DB::MergeTreeReadTask::read(DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002c82d05b 22. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:53: DB::MergeTreeInOrderSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&, DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002dea5374 23. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:0: DB::MergeTreeSelectProcessor::read() @ 0x000000002c8242f9 24. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000002de6d77a 25. ./build_docker/./src/Processors/ISource.cpp:0: DB::ISource::work() @ 0x000000002d3290a1 26. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 27. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 28. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 29. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 30. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 31. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 2025.09.09 15:06:56.144162 [ 19252 ] {94fd93d5-e7ef-4590-b659-70ee5acd5fe1} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=9, jobs=0): (while reading column key_column): (while reading from part /var/lib/clickhouse/store/cab/cabf9a66-80e2-4148-8335-3c53187f5a8a/all_1_1_0/ in table database_for_dict.table_for_dict (cabf9a66-80e2-4148-8335-3c53187f5a8a) located on disk default of type local, from mark 0 with max_rows_to_read = 1): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder): while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af80b71 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80746 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000266005a2 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000265fffb4 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:1197: ? @ 0x00000000265fd4e7 9. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:62: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x00000000265e6fbd 10. ./contrib/llvm-project/libcxx/include/future:1123: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x00000000265e7bb3 11. DB::ReadBuffer::next() @ 0x000000000b528aeb 12. ./src/IO/ReadBuffer.h:0: DB::CompressedReadBufferBase::readCompressedDataBlockForAsynchronous(unsigned long&, unsigned long&) @ 0x0000000027760e7f 13. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:110: DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x0000000027764c41 14. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:222: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x0000000027b97730 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 @ 0x0000000027aa00db 16. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:0: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x000000002c7b254b 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7eb79e 18. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:118: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7c9d8a 19. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x000000002c7e0473 20. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x000000002c7dbec3 21. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:0: DB::MergeTreeReadTask::read(DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002c82d05b 22. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:53: DB::MergeTreeInOrderSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&, DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002dea5374 23. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:0: DB::MergeTreeSelectProcessor::read() @ 0x000000002c8242f9 24. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000002de6d77a 25. ./build_docker/./src/Processors/ISource.cpp:0: DB::ISource::work() @ 0x000000002d3290a1 26. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 27. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 28. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 29. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 30. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 31. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 2025.09.09 15:06:56.150473 [ 2881 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:06:56.163110 [ 20353 ] {479bd4ee-1314-4e4a-b3b0-6c1d92eb3fb2} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=9, jobs=0): (while reading column key_column): (while reading from part /var/lib/clickhouse/store/cab/cabf9a66-80e2-4148-8335-3c53187f5a8a/all_1_1_0/ in table database_for_dict.table_for_dict (cabf9a66-80e2-4148-8335-3c53187f5a8a) located on disk default of type local, from mark 0 with max_rows_to_read = 1): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder): while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:60580) (comment: 01542_dictionary_load_exception_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af80b71 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80746 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000266005a2 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000265fffb4 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:1197: ? @ 0x00000000265fd4e7 9. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:62: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x00000000265e6fbd 10. ./contrib/llvm-project/libcxx/include/future:1123: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x00000000265e7bb3 11. DB::ReadBuffer::next() @ 0x000000000b528aeb 12. ./src/IO/ReadBuffer.h:0: DB::CompressedReadBufferBase::readCompressedDataBlockForAsynchronous(unsigned long&, unsigned long&) @ 0x0000000027760e7f 13. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:110: DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x0000000027764c41 14. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:222: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x0000000027b97730 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 @ 0x0000000027aa00db 16. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:0: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x000000002c7b254b 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7eb79e 18. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:118: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7c9d8a 19. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x000000002c7e0473 20. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x000000002c7dbec3 21. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:0: DB::MergeTreeReadTask::read(DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002c82d05b 22. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:53: DB::MergeTreeInOrderSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&, DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002dea5374 23. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:0: DB::MergeTreeSelectProcessor::read() @ 0x000000002c8242f9 24. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000002de6d77a 25. ./build_docker/./src/Processors/ISource.cpp:0: DB::ISource::work() @ 0x000000002d3290a1 26. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 27. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 28. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 29. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 30. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 31. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 2025.09.09 15:06:56.170767 [ 20353 ] {479bd4ee-1314-4e4a-b3b0-6c1d92eb3fb2} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=9, jobs=0): (while reading column key_column): (while reading from part /var/lib/clickhouse/store/cab/cabf9a66-80e2-4148-8335-3c53187f5a8a/all_1_1_0/ in table database_for_dict.table_for_dict (cabf9a66-80e2-4148-8335-3c53187f5a8a) located on disk default of type local, from mark 0 with max_rows_to_read = 1): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder): while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af80b71 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80746 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000266005a2 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000265fffb4 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:1197: ? @ 0x00000000265fd4e7 9. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:62: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x00000000265e6fbd 10. ./contrib/llvm-project/libcxx/include/future:1123: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x00000000265e7bb3 11. DB::ReadBuffer::next() @ 0x000000000b528aeb 12. ./src/IO/ReadBuffer.h:0: DB::CompressedReadBufferBase::readCompressedDataBlockForAsynchronous(unsigned long&, unsigned long&) @ 0x0000000027760e7f 13. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:110: DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x0000000027764c41 14. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:222: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x0000000027b97730 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 @ 0x0000000027aa00db 16. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:0: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x000000002c7b254b 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7eb79e 18. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:118: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7c9d8a 19. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x000000002c7e0473 20. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x000000002c7dbec3 21. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:0: DB::MergeTreeReadTask::read(DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002c82d05b 22. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:53: DB::MergeTreeInOrderSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&, DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002dea5374 23. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:0: DB::MergeTreeSelectProcessor::read() @ 0x000000002c8242f9 24. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000002de6d77a 25. ./build_docker/./src/Processors/ISource.cpp:0: DB::ISource::work() @ 0x000000002d3290a1 26. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 27. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 28. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 29. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 30. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 31. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 2025.09.09 15:06:56.177214 [ 20350 ] {fdfb8fcb-ecff-4a4f-a49a-e1aa5f1749f9} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=9, jobs=0): (while reading column key_column): (while reading from part /var/lib/clickhouse/store/cab/cabf9a66-80e2-4148-8335-3c53187f5a8a/all_1_1_0/ in table database_for_dict.table_for_dict (cabf9a66-80e2-4148-8335-3c53187f5a8a) located on disk default of type local, from mark 0 with max_rows_to_read = 1): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder): while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:60554) (comment: 01542_dictionary_load_exception_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af80b71 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80746 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000266005a2 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000265fffb4 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:1197: ? @ 0x00000000265fd4e7 9. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:62: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x00000000265e6fbd 10. ./contrib/llvm-project/libcxx/include/future:1123: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x00000000265e7bb3 11. DB::ReadBuffer::next() @ 0x000000000b528aeb 12. ./src/IO/ReadBuffer.h:0: DB::CompressedReadBufferBase::readCompressedDataBlockForAsynchronous(unsigned long&, unsigned long&) @ 0x0000000027760e7f 13. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:110: DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x0000000027764c41 14. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:222: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x0000000027b97730 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 @ 0x0000000027aa00db 16. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:0: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x000000002c7b254b 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7eb79e 18. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:118: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7c9d8a 19. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x000000002c7e0473 20. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x000000002c7dbec3 21. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:0: DB::MergeTreeReadTask::read(DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002c82d05b 22. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:53: DB::MergeTreeInOrderSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&, DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002dea5374 23. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:0: DB::MergeTreeSelectProcessor::read() @ 0x000000002c8242f9 24. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000002de6d77a 25. ./build_docker/./src/Processors/ISource.cpp:0: DB::ISource::work() @ 0x000000002d3290a1 26. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 27. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 28. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 29. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 30. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 31. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 2025.09.09 15:06:56.214247 [ 20355 ] {42295009-2e89-4ee0-bb0d-be9009dc3393} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=9, jobs=0): (while reading column key_column): (while reading from part /var/lib/clickhouse/store/cab/cabf9a66-80e2-4148-8335-3c53187f5a8a/all_1_1_0/ in table database_for_dict.table_for_dict (cabf9a66-80e2-4148-8335-3c53187f5a8a) located on disk default of type local, from mark 0 with max_rows_to_read = 1): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder): while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:60584) (comment: 01542_dictionary_load_exception_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af80b71 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80746 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000266005a2 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000265fffb4 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:1197: ? @ 0x00000000265fd4e7 9. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:62: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x00000000265e6fbd 10. ./contrib/llvm-project/libcxx/include/future:1123: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x00000000265e7bb3 11. DB::ReadBuffer::next() @ 0x000000000b528aeb 12. ./src/IO/ReadBuffer.h:0: DB::CompressedReadBufferBase::readCompressedDataBlockForAsynchronous(unsigned long&, unsigned long&) @ 0x0000000027760e7f 13. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:110: DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x0000000027764c41 14. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:222: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x0000000027b97730 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 @ 0x0000000027aa00db 16. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:0: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x000000002c7b254b 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7eb79e 18. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:118: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7c9d8a 19. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x000000002c7e0473 20. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x000000002c7dbec3 21. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:0: DB::MergeTreeReadTask::read(DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002c82d05b 22. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:53: DB::MergeTreeInOrderSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&, DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002dea5374 23. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:0: DB::MergeTreeSelectProcessor::read() @ 0x000000002c8242f9 24. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000002de6d77a 25. ./build_docker/./src/Processors/ISource.cpp:0: DB::ISource::work() @ 0x000000002d3290a1 26. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 27. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 28. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 29. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 30. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 31. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 2025.09.09 15:06:56.216769 [ 20355 ] {42295009-2e89-4ee0-bb0d-be9009dc3393} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=9, jobs=0): (while reading column key_column): (while reading from part /var/lib/clickhouse/store/cab/cabf9a66-80e2-4148-8335-3c53187f5a8a/all_1_1_0/ in table database_for_dict.table_for_dict (cabf9a66-80e2-4148-8335-3c53187f5a8a) located on disk default of type local, from mark 0 with max_rows_to_read = 1): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder): while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af80b71 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80746 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000266005a2 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000265fffb4 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:1197: ? @ 0x00000000265fd4e7 9. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:62: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x00000000265e6fbd 10. ./contrib/llvm-project/libcxx/include/future:1123: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x00000000265e7bb3 11. DB::ReadBuffer::next() @ 0x000000000b528aeb 12. ./src/IO/ReadBuffer.h:0: DB::CompressedReadBufferBase::readCompressedDataBlockForAsynchronous(unsigned long&, unsigned long&) @ 0x0000000027760e7f 13. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:110: DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x0000000027764c41 14. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:222: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x0000000027b97730 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 @ 0x0000000027aa00db 16. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:0: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x000000002c7b254b 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7eb79e 18. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:118: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7c9d8a 19. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x000000002c7e0473 20. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x000000002c7dbec3 21. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:0: DB::MergeTreeReadTask::read(DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002c82d05b 22. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:53: DB::MergeTreeInOrderSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&, DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002dea5374 23. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:0: DB::MergeTreeSelectProcessor::read() @ 0x000000002c8242f9 24. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000002de6d77a 25. ./build_docker/./src/Processors/ISource.cpp:0: DB::ISource::work() @ 0x000000002d3290a1 26. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 27. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 28. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 29. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 30. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 31. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 2025.09.09 15:06:56.226479 [ 20350 ] {fdfb8fcb-ecff-4a4f-a49a-e1aa5f1749f9} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=9, jobs=0): (while reading column key_column): (while reading from part /var/lib/clickhouse/store/cab/cabf9a66-80e2-4148-8335-3c53187f5a8a/all_1_1_0/ in table database_for_dict.table_for_dict (cabf9a66-80e2-4148-8335-3c53187f5a8a) located on disk default of type local, from mark 0 with max_rows_to_read = 1): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder): while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af80b71 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80746 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000266005a2 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000265fffb4 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:1197: ? @ 0x00000000265fd4e7 9. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:62: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x00000000265e6fbd 10. ./contrib/llvm-project/libcxx/include/future:1123: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x00000000265e7bb3 11. DB::ReadBuffer::next() @ 0x000000000b528aeb 12. ./src/IO/ReadBuffer.h:0: DB::CompressedReadBufferBase::readCompressedDataBlockForAsynchronous(unsigned long&, unsigned long&) @ 0x0000000027760e7f 13. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:110: DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x0000000027764c41 14. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:222: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x0000000027b97730 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 @ 0x0000000027aa00db 16. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:0: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x000000002c7b254b 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7eb79e 18. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:118: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7c9d8a 19. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x000000002c7e0473 20. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x000000002c7dbec3 21. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:0: DB::MergeTreeReadTask::read(DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002c82d05b 22. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:53: DB::MergeTreeInOrderSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&, DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002dea5374 23. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:0: DB::MergeTreeSelectProcessor::read() @ 0x000000002c8242f9 24. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000002de6d77a 25. ./build_docker/./src/Processors/ISource.cpp:0: DB::ISource::work() @ 0x000000002d3290a1 26. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 27. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 28. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 29. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 30. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 31. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 2025.09.09 15:06:56.504381 [ 2909 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:06:56.504928 [ 2906 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:06:56.607149 [ 2914 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:06:56.650359 [ 20397 ] {d0945828-e457-4138-bba9-8b88238bd7df} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=9, jobs=0): (while reading column key_column): (while reading from part /var/lib/clickhouse/store/cab/cabf9a66-80e2-4148-8335-3c53187f5a8a/all_1_1_0/ in table database_for_dict.table_for_dict (cabf9a66-80e2-4148-8335-3c53187f5a8a) located on disk default of type local, from mark 0 with max_rows_to_read = 1): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder): while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:60644) (comment: 01542_dictionary_load_exception_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af80b71 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80746 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000266005a2 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000265fffb4 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:1197: ? @ 0x00000000265fd4e7 9. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:62: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x00000000265e6fbd 10. ./contrib/llvm-project/libcxx/include/future:1123: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x00000000265e7bb3 11. DB::ReadBuffer::next() @ 0x000000000b528aeb 12. ./src/IO/ReadBuffer.h:0: DB::CompressedReadBufferBase::readCompressedDataBlockForAsynchronous(unsigned long&, unsigned long&) @ 0x0000000027760e7f 13. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:110: DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x0000000027764c41 14. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:222: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x0000000027b97730 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 @ 0x0000000027aa00db 16. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:0: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x000000002c7b254b 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7eb79e 18. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:118: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7c9d8a 19. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x000000002c7e0473 20. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x000000002c7dbec3 21. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:0: DB::MergeTreeReadTask::read(DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002c82d05b 22. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:53: DB::MergeTreeInOrderSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&, DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002dea5374 23. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:0: DB::MergeTreeSelectProcessor::read() @ 0x000000002c8242f9 24. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000002de6d77a 25. ./build_docker/./src/Processors/ISource.cpp:0: DB::ISource::work() @ 0x000000002d3290a1 26. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 27. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 28. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 29. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 30. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 31. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 2025.09.09 15:06:56.652574 [ 20397 ] {d0945828-e457-4138-bba9-8b88238bd7df} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=9, jobs=0): (while reading column key_column): (while reading from part /var/lib/clickhouse/store/cab/cabf9a66-80e2-4148-8335-3c53187f5a8a/all_1_1_0/ in table database_for_dict.table_for_dict (cabf9a66-80e2-4148-8335-3c53187f5a8a) located on disk default of type local, from mark 0 with max_rows_to_read = 1): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder): while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af80b71 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80746 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000266005a2 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000265fffb4 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:1197: ? @ 0x00000000265fd4e7 9. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:62: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x00000000265e6fbd 10. ./contrib/llvm-project/libcxx/include/future:1123: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x00000000265e7bb3 11. DB::ReadBuffer::next() @ 0x000000000b528aeb 12. ./src/IO/ReadBuffer.h:0: DB::CompressedReadBufferBase::readCompressedDataBlockForAsynchronous(unsigned long&, unsigned long&) @ 0x0000000027760e7f 13. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:110: DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x0000000027764c41 14. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:222: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x0000000027b97730 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 @ 0x0000000027aa00db 16. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:0: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x000000002c7b254b 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7eb79e 18. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:118: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7c9d8a 19. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x000000002c7e0473 20. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x000000002c7dbec3 21. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:0: DB::MergeTreeReadTask::read(DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002c82d05b 22. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:53: DB::MergeTreeInOrderSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&, DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002dea5374 23. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:0: DB::MergeTreeSelectProcessor::read() @ 0x000000002c8242f9 24. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000002de6d77a 25. ./build_docker/./src/Processors/ISource.cpp:0: DB::ISource::work() @ 0x000000002d3290a1 26. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 27. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 28. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 29. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 30. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 31. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 2025.09.09 15:06:56.667939 [ 20343 ] {f5345f73-b424-4fcb-97c9-220440985071} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=9, jobs=0): (while reading column key_column): (while reading from part /var/lib/clickhouse/store/cab/cabf9a66-80e2-4148-8335-3c53187f5a8a/all_1_1_0/ in table database_for_dict.table_for_dict (cabf9a66-80e2-4148-8335-3c53187f5a8a) located on disk default of type local, from mark 0 with max_rows_to_read = 1): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder): while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:60646) (comment: 01542_dictionary_load_exception_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af80b71 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80746 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000266005a2 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000265fffb4 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:1197: ? @ 0x00000000265fd4e7 9. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:62: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x00000000265e6fbd 10. ./contrib/llvm-project/libcxx/include/future:1123: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x00000000265e7bb3 11. DB::ReadBuffer::next() @ 0x000000000b528aeb 12. ./src/IO/ReadBuffer.h:0: DB::CompressedReadBufferBase::readCompressedDataBlockForAsynchronous(unsigned long&, unsigned long&) @ 0x0000000027760e7f 13. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:110: DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x0000000027764c41 14. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:222: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x0000000027b97730 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 @ 0x0000000027aa00db 16. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:0: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x000000002c7b254b 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7eb79e 18. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:118: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7c9d8a 19. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x000000002c7e0473 20. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x000000002c7dbec3 21. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:0: DB::MergeTreeReadTask::read(DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002c82d05b 22. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:53: DB::MergeTreeInOrderSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&, DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002dea5374 23. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:0: DB::MergeTreeSelectProcessor::read() @ 0x000000002c8242f9 24. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000002de6d77a 25. ./build_docker/./src/Processors/ISource.cpp:0: DB::ISource::work() @ 0x000000002d3290a1 26. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 27. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 28. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 29. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 30. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 31. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 2025.09.09 15:06:56.672830 [ 20343 ] {f5345f73-b424-4fcb-97c9-220440985071} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=9, jobs=0): (while reading column key_column): (while reading from part /var/lib/clickhouse/store/cab/cabf9a66-80e2-4148-8335-3c53187f5a8a/all_1_1_0/ in table database_for_dict.table_for_dict (cabf9a66-80e2-4148-8335-3c53187f5a8a) located on disk default of type local, from mark 0 with max_rows_to_read = 1): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder): while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af80b71 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80746 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000266005a2 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000265fffb4 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:1197: ? @ 0x00000000265fd4e7 9. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:62: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x00000000265e6fbd 10. ./contrib/llvm-project/libcxx/include/future:1123: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x00000000265e7bb3 11. DB::ReadBuffer::next() @ 0x000000000b528aeb 12. ./src/IO/ReadBuffer.h:0: DB::CompressedReadBufferBase::readCompressedDataBlockForAsynchronous(unsigned long&, unsigned long&) @ 0x0000000027760e7f 13. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:110: DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x0000000027764c41 14. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:222: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x0000000027b97730 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 @ 0x0000000027aa00db 16. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:0: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x000000002c7b254b 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7eb79e 18. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:118: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7c9d8a 19. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x000000002c7e0473 20. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x000000002c7dbec3 21. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:0: DB::MergeTreeReadTask::read(DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002c82d05b 22. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:53: DB::MergeTreeInOrderSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&, DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002dea5374 23. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:0: DB::MergeTreeSelectProcessor::read() @ 0x000000002c8242f9 24. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000002de6d77a 25. ./build_docker/./src/Processors/ISource.cpp:0: DB::ISource::work() @ 0x000000002d3290a1 26. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 27. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 28. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 29. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 30. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 31. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 2025.09.09 15:06:56.757115 [ 20350 ] {eb13aed6-7fa2-483f-92f9-edc1847caeda} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=9, jobs=0): (while reading column key_column): (while reading from part /var/lib/clickhouse/store/cab/cabf9a66-80e2-4148-8335-3c53187f5a8a/all_1_1_0/ in table database_for_dict.table_for_dict (cabf9a66-80e2-4148-8335-3c53187f5a8a) located on disk default of type local, from mark 0 with max_rows_to_read = 1): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder): while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:60652) (comment: 01542_dictionary_load_exception_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af80b71 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80746 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000266005a2 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000265fffb4 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:1197: ? @ 0x00000000265fd4e7 9. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:62: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x00000000265e6fbd 10. ./contrib/llvm-project/libcxx/include/future:1123: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x00000000265e7bb3 11. DB::ReadBuffer::next() @ 0x000000000b528aeb 12. ./src/IO/ReadBuffer.h:0: DB::CompressedReadBufferBase::readCompressedDataBlockForAsynchronous(unsigned long&, unsigned long&) @ 0x0000000027760e7f 13. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:110: DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x0000000027764c41 14. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:222: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x0000000027b97730 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 @ 0x0000000027aa00db 16. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:0: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x000000002c7b254b 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7eb79e 18. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:118: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7c9d8a 19. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x000000002c7e0473 20. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x000000002c7dbec3 21. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:0: DB::MergeTreeReadTask::read(DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002c82d05b 22. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:53: DB::MergeTreeInOrderSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&, DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002dea5374 23. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:0: DB::MergeTreeSelectProcessor::read() @ 0x000000002c8242f9 24. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000002de6d77a 25. ./build_docker/./src/Processors/ISource.cpp:0: DB::ISource::work() @ 0x000000002d3290a1 26. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 27. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 28. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 29. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 30. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 31. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 2025.09.09 15:06:56.759515 [ 20350 ] {eb13aed6-7fa2-483f-92f9-edc1847caeda} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=9, jobs=0): (while reading column key_column): (while reading from part /var/lib/clickhouse/store/cab/cabf9a66-80e2-4148-8335-3c53187f5a8a/all_1_1_0/ in table database_for_dict.table_for_dict (cabf9a66-80e2-4148-8335-3c53187f5a8a) located on disk default of type local, from mark 0 with max_rows_to_read = 1): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder): while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af80b71 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80746 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000266005a2 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000265fffb4 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:1197: ? @ 0x00000000265fd4e7 9. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:62: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x00000000265e6fbd 10. ./contrib/llvm-project/libcxx/include/future:1123: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x00000000265e7bb3 11. DB::ReadBuffer::next() @ 0x000000000b528aeb 12. ./src/IO/ReadBuffer.h:0: DB::CompressedReadBufferBase::readCompressedDataBlockForAsynchronous(unsigned long&, unsigned long&) @ 0x0000000027760e7f 13. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:110: DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x0000000027764c41 14. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:222: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x0000000027b97730 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 @ 0x0000000027aa00db 16. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:0: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x000000002c7b254b 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7eb79e 18. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:118: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7c9d8a 19. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x000000002c7e0473 20. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x000000002c7dbec3 21. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:0: DB::MergeTreeReadTask::read(DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002c82d05b 22. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:53: DB::MergeTreeInOrderSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&, DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002dea5374 23. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:0: DB::MergeTreeSelectProcessor::read() @ 0x000000002c8242f9 24. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000002de6d77a 25. ./build_docker/./src/Processors/ISource.cpp:0: DB::ISource::work() @ 0x000000002d3290a1 26. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 27. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 28. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 29. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 30. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 31. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 2025.09.09 15:06:56.931969 [ 20351 ] {74e42193-9ec9-4dbf-a606-cf82694ae042} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=9, jobs=0): (while reading column key_column): (while reading from part /var/lib/clickhouse/store/cab/cabf9a66-80e2-4148-8335-3c53187f5a8a/all_1_1_0/ in table database_for_dict.table_for_dict (cabf9a66-80e2-4148-8335-3c53187f5a8a) located on disk default of type local, from mark 0 with max_rows_to_read = 1): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder): while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:60654) (comment: 01542_dictionary_load_exception_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af80b71 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80746 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000266005a2 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000265fffb4 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:1197: ? @ 0x00000000265fd4e7 9. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:62: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x00000000265e6fbd 10. ./contrib/llvm-project/libcxx/include/future:1123: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x00000000265e7bb3 11. DB::ReadBuffer::next() @ 0x000000000b528aeb 12. ./src/IO/ReadBuffer.h:0: DB::CompressedReadBufferBase::readCompressedDataBlockForAsynchronous(unsigned long&, unsigned long&) @ 0x0000000027760e7f 13. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:110: DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x0000000027764c41 14. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:222: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x0000000027b97730 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 @ 0x0000000027aa00db 16. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:0: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x000000002c7b254b 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7eb79e 18. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:118: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7c9d8a 19. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x000000002c7e0473 20. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x000000002c7dbec3 21. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:0: DB::MergeTreeReadTask::read(DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002c82d05b 22. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:53: DB::MergeTreeInOrderSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&, DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002dea5374 23. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:0: DB::MergeTreeSelectProcessor::read() @ 0x000000002c8242f9 24. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000002de6d77a 25. ./build_docker/./src/Processors/ISource.cpp:0: DB::ISource::work() @ 0x000000002d3290a1 26. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 27. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 28. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 29. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 30. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 31. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 2025.09.09 15:06:56.934223 [ 20351 ] {74e42193-9ec9-4dbf-a606-cf82694ae042} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=9, jobs=0): (while reading column key_column): (while reading from part /var/lib/clickhouse/store/cab/cabf9a66-80e2-4148-8335-3c53187f5a8a/all_1_1_0/ in table database_for_dict.table_for_dict (cabf9a66-80e2-4148-8335-3c53187f5a8a) located on disk default of type local, from mark 0 with max_rows_to_read = 1): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder): while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af80b71 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80746 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000266005a2 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000265fffb4 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:1197: ? @ 0x00000000265fd4e7 9. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:62: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x00000000265e6fbd 10. ./contrib/llvm-project/libcxx/include/future:1123: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x00000000265e7bb3 11. DB::ReadBuffer::next() @ 0x000000000b528aeb 12. ./src/IO/ReadBuffer.h:0: DB::CompressedReadBufferBase::readCompressedDataBlockForAsynchronous(unsigned long&, unsigned long&) @ 0x0000000027760e7f 13. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:110: DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x0000000027764c41 14. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:222: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x0000000027b97730 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 @ 0x0000000027aa00db 16. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:0: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x000000002c7b254b 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7eb79e 18. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:118: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7c9d8a 19. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x000000002c7e0473 20. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x000000002c7dbec3 21. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:0: DB::MergeTreeReadTask::read(DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002c82d05b 22. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:53: DB::MergeTreeInOrderSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&, DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002dea5374 23. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:0: DB::MergeTreeSelectProcessor::read() @ 0x000000002c8242f9 24. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000002de6d77a 25. ./build_docker/./src/Processors/ISource.cpp:0: DB::ISource::work() @ 0x000000002d3290a1 26. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 27. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 28. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 29. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 30. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 31. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 2025.09.09 15:06:56.942251 [ 20355 ] {a65f5cf2-e32b-408d-88e9-2b8dbd053de3} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=9, jobs=0): (while reading column key_column): (while reading from part /var/lib/clickhouse/store/cab/cabf9a66-80e2-4148-8335-3c53187f5a8a/all_1_1_0/ in table database_for_dict.table_for_dict (cabf9a66-80e2-4148-8335-3c53187f5a8a) located on disk default of type local, from mark 0 with max_rows_to_read = 1): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder): while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:60676) (comment: 01542_dictionary_load_exception_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af80b71 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80746 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000266005a2 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000265fffb4 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:1197: ? @ 0x00000000265fd4e7 9. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:62: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x00000000265e6fbd 10. ./contrib/llvm-project/libcxx/include/future:1123: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x00000000265e7bb3 11. DB::ReadBuffer::next() @ 0x000000000b528aeb 12. ./src/IO/ReadBuffer.h:0: DB::CompressedReadBufferBase::readCompressedDataBlockForAsynchronous(unsigned long&, unsigned long&) @ 0x0000000027760e7f 13. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:110: DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x0000000027764c41 14. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:222: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x0000000027b97730 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 @ 0x0000000027aa00db 16. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:0: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x000000002c7b254b 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7eb79e 18. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:118: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7c9d8a 19. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x000000002c7e0473 20. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x000000002c7dbec3 21. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:0: DB::MergeTreeReadTask::read(DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002c82d05b 22. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:53: DB::MergeTreeInOrderSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&, DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002dea5374 23. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:0: DB::MergeTreeSelectProcessor::read() @ 0x000000002c8242f9 24. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000002de6d77a 25. ./build_docker/./src/Processors/ISource.cpp:0: DB::ISource::work() @ 0x000000002d3290a1 26. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 27. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 28. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 29. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 30. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 31. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 2025.09.09 15:06:56.946518 [ 20355 ] {a65f5cf2-e32b-408d-88e9-2b8dbd053de3} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=9, jobs=0): (while reading column key_column): (while reading from part /var/lib/clickhouse/store/cab/cabf9a66-80e2-4148-8335-3c53187f5a8a/all_1_1_0/ in table database_for_dict.table_for_dict (cabf9a66-80e2-4148-8335-3c53187f5a8a) located on disk default of type local, from mark 0 with max_rows_to_read = 1): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder): while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af80b71 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80746 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000266005a2 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000265fffb4 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:1197: ? @ 0x00000000265fd4e7 9. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:62: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x00000000265e6fbd 10. ./contrib/llvm-project/libcxx/include/future:1123: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x00000000265e7bb3 11. DB::ReadBuffer::next() @ 0x000000000b528aeb 12. ./src/IO/ReadBuffer.h:0: DB::CompressedReadBufferBase::readCompressedDataBlockForAsynchronous(unsigned long&, unsigned long&) @ 0x0000000027760e7f 13. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:110: DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x0000000027764c41 14. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:222: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x0000000027b97730 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 @ 0x0000000027aa00db 16. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:0: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x000000002c7b254b 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7eb79e 18. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:118: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7c9d8a 19. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x000000002c7e0473 20. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x000000002c7dbec3 21. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:0: DB::MergeTreeReadTask::read(DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002c82d05b 22. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:53: DB::MergeTreeInOrderSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&, DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002dea5374 23. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:0: DB::MergeTreeSelectProcessor::read() @ 0x000000002c8242f9 24. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000002de6d77a 25. ./build_docker/./src/Processors/ISource.cpp:0: DB::ISource::work() @ 0x000000002d3290a1 26. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 27. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 28. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 29. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 30. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 31. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 2025.09.09 15:06:56.961435 [ 19252 ] {79d9083f-801a-42bd-9557-dc808e519753} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=9, jobs=0): (while reading column key_column): (while reading from part /var/lib/clickhouse/store/cab/cabf9a66-80e2-4148-8335-3c53187f5a8a/all_1_1_0/ in table database_for_dict.table_for_dict (cabf9a66-80e2-4148-8335-3c53187f5a8a) located on disk default of type local, from mark 0 with max_rows_to_read = 1): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder): while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:60694) (comment: 01542_dictionary_load_exception_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af80b71 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80746 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000266005a2 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000265fffb4 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:1197: ? @ 0x00000000265fd4e7 9. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:62: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x00000000265e6fbd 10. ./contrib/llvm-project/libcxx/include/future:1123: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x00000000265e7bb3 11. DB::ReadBuffer::next() @ 0x000000000b528aeb 12. ./src/IO/ReadBuffer.h:0: DB::CompressedReadBufferBase::readCompressedDataBlockForAsynchronous(unsigned long&, unsigned long&) @ 0x0000000027760e7f 13. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:110: DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x0000000027764c41 14. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:222: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x0000000027b97730 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 @ 0x0000000027aa00db 16. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:0: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x000000002c7b254b 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7eb79e 18. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:118: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7c9d8a 19. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x000000002c7e0473 20. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x000000002c7dbec3 21. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:0: DB::MergeTreeReadTask::read(DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002c82d05b 22. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:53: DB::MergeTreeInOrderSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&, DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002dea5374 23. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:0: DB::MergeTreeSelectProcessor::read() @ 0x000000002c8242f9 24. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000002de6d77a 25. ./build_docker/./src/Processors/ISource.cpp:0: DB::ISource::work() @ 0x000000002d3290a1 26. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 27. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 28. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 29. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 30. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 31. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 2025.09.09 15:06:56.963736 [ 19252 ] {79d9083f-801a-42bd-9557-dc808e519753} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=9, jobs=0): (while reading column key_column): (while reading from part /var/lib/clickhouse/store/cab/cabf9a66-80e2-4148-8335-3c53187f5a8a/all_1_1_0/ in table database_for_dict.table_for_dict (cabf9a66-80e2-4148-8335-3c53187f5a8a) located on disk default of type local, from mark 0 with max_rows_to_read = 1): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder): while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af80b71 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80746 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000266005a2 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000265fffb4 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:1197: ? @ 0x00000000265fd4e7 9. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:62: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x00000000265e6fbd 10. ./contrib/llvm-project/libcxx/include/future:1123: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x00000000265e7bb3 11. DB::ReadBuffer::next() @ 0x000000000b528aeb 12. ./src/IO/ReadBuffer.h:0: DB::CompressedReadBufferBase::readCompressedDataBlockForAsynchronous(unsigned long&, unsigned long&) @ 0x0000000027760e7f 13. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:110: DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x0000000027764c41 14. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:222: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x0000000027b97730 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 @ 0x0000000027aa00db 16. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:0: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x000000002c7b254b 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7eb79e 18. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:118: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7c9d8a 19. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x000000002c7e0473 20. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x000000002c7dbec3 21. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:0: DB::MergeTreeReadTask::read(DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002c82d05b 22. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:53: DB::MergeTreeInOrderSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&, DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002dea5374 23. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:0: DB::MergeTreeSelectProcessor::read() @ 0x000000002c8242f9 24. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000002de6d77a 25. ./build_docker/./src/Processors/ISource.cpp:0: DB::ISource::work() @ 0x000000002d3290a1 26. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 27. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 28. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 29. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 30. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 31. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 2025.09.09 15:06:56.984092 [ 20345 ] {56de957b-979b-445d-bb84-5c50df14af63} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=9, jobs=0): (while reading column key_column): (while reading from part /var/lib/clickhouse/store/cab/cabf9a66-80e2-4148-8335-3c53187f5a8a/all_1_1_0/ in table database_for_dict.table_for_dict (cabf9a66-80e2-4148-8335-3c53187f5a8a) located on disk default of type local, from mark 0 with max_rows_to_read = 1): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder): while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:60680) (comment: 01542_dictionary_load_exception_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af80b71 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80746 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000266005a2 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000265fffb4 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:1197: ? @ 0x00000000265fd4e7 9. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:62: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x00000000265e6fbd 10. ./contrib/llvm-project/libcxx/include/future:1123: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x00000000265e7bb3 11. DB::ReadBuffer::next() @ 0x000000000b528aeb 12. ./src/IO/ReadBuffer.h:0: DB::CompressedReadBufferBase::readCompressedDataBlockForAsynchronous(unsigned long&, unsigned long&) @ 0x0000000027760e7f 13. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:110: DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x0000000027764c41 14. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:222: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x0000000027b97730 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 @ 0x0000000027aa00db 16. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:0: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x000000002c7b254b 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7eb79e 18. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:118: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7c9d8a 19. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x000000002c7e0473 20. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x000000002c7dbec3 21. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:0: DB::MergeTreeReadTask::read(DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002c82d05b 22. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:53: DB::MergeTreeInOrderSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&, DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002dea5374 23. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:0: DB::MergeTreeSelectProcessor::read() @ 0x000000002c8242f9 24. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000002de6d77a 25. ./build_docker/./src/Processors/ISource.cpp:0: DB::ISource::work() @ 0x000000002d3290a1 26. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 27. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 28. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 29. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 30. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 31. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 2025.09.09 15:06:56.995166 [ 20345 ] {56de957b-979b-445d-bb84-5c50df14af63} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=9, jobs=0): (while reading column key_column): (while reading from part /var/lib/clickhouse/store/cab/cabf9a66-80e2-4148-8335-3c53187f5a8a/all_1_1_0/ in table database_for_dict.table_for_dict (cabf9a66-80e2-4148-8335-3c53187f5a8a) located on disk default of type local, from mark 0 with max_rows_to_read = 1): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder): while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af80b71 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80746 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000266005a2 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000265fffb4 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:1197: ? @ 0x00000000265fd4e7 9. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:62: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x00000000265e6fbd 10. ./contrib/llvm-project/libcxx/include/future:1123: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x00000000265e7bb3 11. DB::ReadBuffer::next() @ 0x000000000b528aeb 12. ./src/IO/ReadBuffer.h:0: DB::CompressedReadBufferBase::readCompressedDataBlockForAsynchronous(unsigned long&, unsigned long&) @ 0x0000000027760e7f 13. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:110: DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x0000000027764c41 14. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:222: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x0000000027b97730 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 @ 0x0000000027aa00db 16. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:0: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x000000002c7b254b 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7eb79e 18. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:118: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7c9d8a 19. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x000000002c7e0473 20. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x000000002c7dbec3 21. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:0: DB::MergeTreeReadTask::read(DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002c82d05b 22. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:53: DB::MergeTreeInOrderSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&, DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002dea5374 23. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:0: DB::MergeTreeSelectProcessor::read() @ 0x000000002c8242f9 24. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000002de6d77a 25. ./build_docker/./src/Processors/ISource.cpp:0: DB::ISource::work() @ 0x000000002d3290a1 26. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 27. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 28. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 29. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 30. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 31. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 2025.09.09 15:06:57.009434 [ 20379 ] {a565462d-c562-4c92-bfe5-cc76cf431cee} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=9, jobs=0): (while reading column key_column): (while reading from part /var/lib/clickhouse/store/cab/cabf9a66-80e2-4148-8335-3c53187f5a8a/all_1_1_0/ in table database_for_dict.table_for_dict (cabf9a66-80e2-4148-8335-3c53187f5a8a) located on disk default of type local, from mark 0 with max_rows_to_read = 1): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder): while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:60678) (comment: 01542_dictionary_load_exception_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af80b71 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80746 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000266005a2 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000265fffb4 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:1197: ? @ 0x00000000265fd4e7 9. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:62: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x00000000265e6fbd 10. ./contrib/llvm-project/libcxx/include/future:1123: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x00000000265e7bb3 11. DB::ReadBuffer::next() @ 0x000000000b528aeb 12. ./src/IO/ReadBuffer.h:0: DB::CompressedReadBufferBase::readCompressedDataBlockForAsynchronous(unsigned long&, unsigned long&) @ 0x0000000027760e7f 13. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:110: DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x0000000027764c41 14. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:222: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x0000000027b97730 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 @ 0x0000000027aa00db 16. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:0: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x000000002c7b254b 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7eb79e 18. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:118: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7c9d8a 19. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x000000002c7e0473 20. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x000000002c7dbec3 21. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:0: DB::MergeTreeReadTask::read(DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002c82d05b 22. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:53: DB::MergeTreeInOrderSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&, DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002dea5374 23. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:0: DB::MergeTreeSelectProcessor::read() @ 0x000000002c8242f9 24. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000002de6d77a 25. ./build_docker/./src/Processors/ISource.cpp:0: DB::ISource::work() @ 0x000000002d3290a1 26. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 27. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 28. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 29. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 30. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 31. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 2025.09.09 15:06:57.019742 [ 20379 ] {a565462d-c562-4c92-bfe5-cc76cf431cee} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=9, jobs=0): (while reading column key_column): (while reading from part /var/lib/clickhouse/store/cab/cabf9a66-80e2-4148-8335-3c53187f5a8a/all_1_1_0/ in table database_for_dict.table_for_dict (cabf9a66-80e2-4148-8335-3c53187f5a8a) located on disk default of type local, from mark 0 with max_rows_to_read = 1): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder): while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af80b71 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80746 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000266005a2 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000265fffb4 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:1197: ? @ 0x00000000265fd4e7 9. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:62: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x00000000265e6fbd 10. ./contrib/llvm-project/libcxx/include/future:1123: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x00000000265e7bb3 11. DB::ReadBuffer::next() @ 0x000000000b528aeb 12. ./src/IO/ReadBuffer.h:0: DB::CompressedReadBufferBase::readCompressedDataBlockForAsynchronous(unsigned long&, unsigned long&) @ 0x0000000027760e7f 13. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:110: DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x0000000027764c41 14. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:222: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x0000000027b97730 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 @ 0x0000000027aa00db 16. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:0: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x000000002c7b254b 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7eb79e 18. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:118: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7c9d8a 19. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x000000002c7e0473 20. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x000000002c7dbec3 21. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:0: DB::MergeTreeReadTask::read(DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002c82d05b 22. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:53: DB::MergeTreeInOrderSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&, DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002dea5374 23. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:0: DB::MergeTreeSelectProcessor::read() @ 0x000000002c8242f9 24. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000002de6d77a 25. ./build_docker/./src/Processors/ISource.cpp:0: DB::ISource::work() @ 0x000000002d3290a1 26. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 27. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 28. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 29. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 30. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 31. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 2025.09.09 15:06:57.022822 [ 20380 ] {f0c0756f-db59-417b-b4f3-46aa3c37f58a} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=9, jobs=0): (while reading column key_column): (while reading from part /var/lib/clickhouse/store/cab/cabf9a66-80e2-4148-8335-3c53187f5a8a/all_1_1_0/ in table database_for_dict.table_for_dict (cabf9a66-80e2-4148-8335-3c53187f5a8a) located on disk default of type local, from mark 0 with max_rows_to_read = 1): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder): while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:60682) (comment: 01542_dictionary_load_exception_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af80b71 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80746 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000266005a2 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000265fffb4 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:1197: ? @ 0x00000000265fd4e7 9. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:62: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x00000000265e6fbd 10. ./contrib/llvm-project/libcxx/include/future:1123: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x00000000265e7bb3 11. DB::ReadBuffer::next() @ 0x000000000b528aeb 12. ./src/IO/ReadBuffer.h:0: DB::CompressedReadBufferBase::readCompressedDataBlockForAsynchronous(unsigned long&, unsigned long&) @ 0x0000000027760e7f 13. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:110: DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x0000000027764c41 14. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:222: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x0000000027b97730 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 @ 0x0000000027aa00db 16. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:0: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x000000002c7b254b 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7eb79e 18. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:118: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7c9d8a 19. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x000000002c7e0473 20. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x000000002c7dbec3 21. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:0: DB::MergeTreeReadTask::read(DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002c82d05b 22. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:53: DB::MergeTreeInOrderSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&, DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002dea5374 23. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:0: DB::MergeTreeSelectProcessor::read() @ 0x000000002c8242f9 24. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000002de6d77a 25. ./build_docker/./src/Processors/ISource.cpp:0: DB::ISource::work() @ 0x000000002d3290a1 26. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 27. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 28. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 29. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 30. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 31. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 2025.09.09 15:06:57.029890 [ 20380 ] {f0c0756f-db59-417b-b4f3-46aa3c37f58a} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=9, jobs=0): (while reading column key_column): (while reading from part /var/lib/clickhouse/store/cab/cabf9a66-80e2-4148-8335-3c53187f5a8a/all_1_1_0/ in table database_for_dict.table_for_dict (cabf9a66-80e2-4148-8335-3c53187f5a8a) located on disk default of type local, from mark 0 with max_rows_to_read = 1): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder): while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af80b71 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80746 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000266005a2 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000265fffb4 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:1197: ? @ 0x00000000265fd4e7 9. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:62: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x00000000265e6fbd 10. ./contrib/llvm-project/libcxx/include/future:1123: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x00000000265e7bb3 11. DB::ReadBuffer::next() @ 0x000000000b528aeb 12. ./src/IO/ReadBuffer.h:0: DB::CompressedReadBufferBase::readCompressedDataBlockForAsynchronous(unsigned long&, unsigned long&) @ 0x0000000027760e7f 13. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:110: DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x0000000027764c41 14. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:222: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x0000000027b97730 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 @ 0x0000000027aa00db 16. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:0: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x000000002c7b254b 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7eb79e 18. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:118: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7c9d8a 19. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x000000002c7e0473 20. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x000000002c7dbec3 21. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:0: DB::MergeTreeReadTask::read(DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002c82d05b 22. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:53: DB::MergeTreeInOrderSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&, DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002dea5374 23. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:0: DB::MergeTreeSelectProcessor::read() @ 0x000000002c8242f9 24. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000002de6d77a 25. ./build_docker/./src/Processors/ISource.cpp:0: DB::ISource::work() @ 0x000000002d3290a1 26. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 27. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 28. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 29. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 30. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 31. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 2025.09.09 15:06:57.030485 [ 20849 ] {313b2795-ce7c-4fd0-affa-923454dcb76b} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=9, jobs=0): (while reading column key_column): (while reading from part /var/lib/clickhouse/store/cab/cabf9a66-80e2-4148-8335-3c53187f5a8a/all_1_1_0/ in table database_for_dict.table_for_dict (cabf9a66-80e2-4148-8335-3c53187f5a8a) located on disk default of type local, from mark 0 with max_rows_to_read = 1): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder): while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:60704) (comment: 01542_dictionary_load_exception_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af80b71 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80746 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000266005a2 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000265fffb4 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:1197: ? @ 0x00000000265fd4e7 9. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:62: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x00000000265e6fbd 10. ./contrib/llvm-project/libcxx/include/future:1123: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x00000000265e7bb3 11. DB::ReadBuffer::next() @ 0x000000000b528aeb 12. ./src/IO/ReadBuffer.h:0: DB::CompressedReadBufferBase::readCompressedDataBlockForAsynchronous(unsigned long&, unsigned long&) @ 0x0000000027760e7f 13. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:110: DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x0000000027764c41 14. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:222: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x0000000027b97730 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 @ 0x0000000027aa00db 16. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:0: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x000000002c7b254b 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7eb79e 18. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:118: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7c9d8a 19. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x000000002c7e0473 20. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x000000002c7dbec3 21. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:0: DB::MergeTreeReadTask::read(DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002c82d05b 22. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:53: DB::MergeTreeInOrderSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&, DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002dea5374 23. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:0: DB::MergeTreeSelectProcessor::read() @ 0x000000002c8242f9 24. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000002de6d77a 25. ./build_docker/./src/Processors/ISource.cpp:0: DB::ISource::work() @ 0x000000002d3290a1 26. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 27. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 28. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 29. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 30. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 31. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 2025.09.09 15:06:57.042256 [ 20849 ] {313b2795-ce7c-4fd0-affa-923454dcb76b} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=9, jobs=0): (while reading column key_column): (while reading from part /var/lib/clickhouse/store/cab/cabf9a66-80e2-4148-8335-3c53187f5a8a/all_1_1_0/ in table database_for_dict.table_for_dict (cabf9a66-80e2-4148-8335-3c53187f5a8a) located on disk default of type local, from mark 0 with max_rows_to_read = 1): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder): while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af80b71 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80746 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000266005a2 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000265fffb4 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:1197: ? @ 0x00000000265fd4e7 9. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:62: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x00000000265e6fbd 10. ./contrib/llvm-project/libcxx/include/future:1123: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x00000000265e7bb3 11. DB::ReadBuffer::next() @ 0x000000000b528aeb 12. ./src/IO/ReadBuffer.h:0: DB::CompressedReadBufferBase::readCompressedDataBlockForAsynchronous(unsigned long&, unsigned long&) @ 0x0000000027760e7f 13. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:110: DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x0000000027764c41 14. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:222: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x0000000027b97730 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 @ 0x0000000027aa00db 16. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:0: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x000000002c7b254b 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7eb79e 18. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:118: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7c9d8a 19. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x000000002c7e0473 20. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x000000002c7dbec3 21. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:0: DB::MergeTreeReadTask::read(DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002c82d05b 22. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:53: DB::MergeTreeInOrderSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&, DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002dea5374 23. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:0: DB::MergeTreeSelectProcessor::read() @ 0x000000002c8242f9 24. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000002de6d77a 25. ./build_docker/./src/Processors/ISource.cpp:0: DB::ISource::work() @ 0x000000002d3290a1 26. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 27. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 28. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 29. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 30. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 31. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 2025.09.09 15:06:57.052741 [ 20881 ] {f66ad031-b9ba-4ba6-a236-e825cc9869a4} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=9, jobs=0): (while reading column key_column): (while reading from part /var/lib/clickhouse/store/cab/cabf9a66-80e2-4148-8335-3c53187f5a8a/all_1_1_0/ in table database_for_dict.table_for_dict (cabf9a66-80e2-4148-8335-3c53187f5a8a) located on disk default of type local, from mark 0 with max_rows_to_read = 1): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder): while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:60706) (comment: 01542_dictionary_load_exception_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af80b71 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80746 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000266005a2 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000265fffb4 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:1197: ? @ 0x00000000265fd4e7 9. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:62: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x00000000265e6fbd 10. ./contrib/llvm-project/libcxx/include/future:1123: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x00000000265e7bb3 11. DB::ReadBuffer::next() @ 0x000000000b528aeb 12. ./src/IO/ReadBuffer.h:0: DB::CompressedReadBufferBase::readCompressedDataBlockForAsynchronous(unsigned long&, unsigned long&) @ 0x0000000027760e7f 13. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:110: DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x0000000027764c41 14. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:222: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x0000000027b97730 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 @ 0x0000000027aa00db 16. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:0: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x000000002c7b254b 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7eb79e 18. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:118: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7c9d8a 19. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x000000002c7e0473 20. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x000000002c7dbec3 21. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:0: DB::MergeTreeReadTask::read(DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002c82d05b 22. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:53: DB::MergeTreeInOrderSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&, DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002dea5374 23. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:0: DB::MergeTreeSelectProcessor::read() @ 0x000000002c8242f9 24. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000002de6d77a 25. ./build_docker/./src/Processors/ISource.cpp:0: DB::ISource::work() @ 0x000000002d3290a1 26. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 27. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 28. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 29. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 30. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 31. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 2025.09.09 15:06:57.054950 [ 20881 ] {f66ad031-b9ba-4ba6-a236-e825cc9869a4} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=9, jobs=0): (while reading column key_column): (while reading from part /var/lib/clickhouse/store/cab/cabf9a66-80e2-4148-8335-3c53187f5a8a/all_1_1_0/ in table database_for_dict.table_for_dict (cabf9a66-80e2-4148-8335-3c53187f5a8a) located on disk default of type local, from mark 0 with max_rows_to_read = 1): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder): while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af80b71 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80746 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000266005a2 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000265fffb4 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:1197: ? @ 0x00000000265fd4e7 9. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:62: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x00000000265e6fbd 10. ./contrib/llvm-project/libcxx/include/future:1123: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x00000000265e7bb3 11. DB::ReadBuffer::next() @ 0x000000000b528aeb 12. ./src/IO/ReadBuffer.h:0: DB::CompressedReadBufferBase::readCompressedDataBlockForAsynchronous(unsigned long&, unsigned long&) @ 0x0000000027760e7f 13. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:110: DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x0000000027764c41 14. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:222: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x0000000027b97730 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 @ 0x0000000027aa00db 16. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:0: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x000000002c7b254b 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7eb79e 18. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:118: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7c9d8a 19. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x000000002c7e0473 20. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x000000002c7dbec3 21. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:0: DB::MergeTreeReadTask::read(DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002c82d05b 22. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:53: DB::MergeTreeInOrderSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&, DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002dea5374 23. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:0: DB::MergeTreeSelectProcessor::read() @ 0x000000002c8242f9 24. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000002de6d77a 25. ./build_docker/./src/Processors/ISource.cpp:0: DB::ISource::work() @ 0x000000002d3290a1 26. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 27. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 28. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 29. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 30. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 31. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 2025.09.09 15:06:57.152224 [ 2980 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:06:57.266138 [ 20161 ] {} test_0473czib.mt (37fd3cf2-879f-4934-ac8d-662471988a31): dropAllData: got exception removing parts from disk, removing successfully removed parts from memory. 2025.09.09 15:06:57.283928 [ 20397 ] {6cdeaba6-ae04-431b-a366-d27348b45dbf} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=9, jobs=0): (while reading column key_column): (while reading from part /var/lib/clickhouse/store/cab/cabf9a66-80e2-4148-8335-3c53187f5a8a/all_1_1_0/ in table database_for_dict.table_for_dict (cabf9a66-80e2-4148-8335-3c53187f5a8a) located on disk default of type local, from mark 0 with max_rows_to_read = 1): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder): while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:60712) (comment: 01542_dictionary_load_exception_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af80b71 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80746 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000266005a2 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000265fffb4 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:1197: ? @ 0x00000000265fd4e7 9. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:62: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x00000000265e6fbd 10. ./contrib/llvm-project/libcxx/include/future:1123: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x00000000265e7bb3 11. DB::ReadBuffer::next() @ 0x000000000b528aeb 12. ./src/IO/ReadBuffer.h:0: DB::CompressedReadBufferBase::readCompressedDataBlockForAsynchronous(unsigned long&, unsigned long&) @ 0x0000000027760e7f 13. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:110: DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x0000000027764c41 14. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:222: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x0000000027b97730 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 @ 0x0000000027aa00db 16. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:0: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x000000002c7b254b 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7eb79e 18. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:118: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7c9d8a 19. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x000000002c7e0473 20. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x000000002c7dbec3 21. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:0: DB::MergeTreeReadTask::read(DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002c82d05b 22. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:53: DB::MergeTreeInOrderSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&, DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002dea5374 23. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:0: DB::MergeTreeSelectProcessor::read() @ 0x000000002c8242f9 24. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000002de6d77a 25. ./build_docker/./src/Processors/ISource.cpp:0: DB::ISource::work() @ 0x000000002d3290a1 26. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 27. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 28. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 29. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 30. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 31. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 2025.09.09 15:06:57.298477 [ 20397 ] {6cdeaba6-ae04-431b-a366-d27348b45dbf} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=9, jobs=0): (while reading column key_column): (while reading from part /var/lib/clickhouse/store/cab/cabf9a66-80e2-4148-8335-3c53187f5a8a/all_1_1_0/ in table database_for_dict.table_for_dict (cabf9a66-80e2-4148-8335-3c53187f5a8a) located on disk default of type local, from mark 0 with max_rows_to_read = 1): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder): while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af80b71 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80746 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000266005a2 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000265fffb4 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:1197: ? @ 0x00000000265fd4e7 9. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:62: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x00000000265e6fbd 10. ./contrib/llvm-project/libcxx/include/future:1123: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x00000000265e7bb3 11. DB::ReadBuffer::next() @ 0x000000000b528aeb 12. ./src/IO/ReadBuffer.h:0: DB::CompressedReadBufferBase::readCompressedDataBlockForAsynchronous(unsigned long&, unsigned long&) @ 0x0000000027760e7f 13. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:110: DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x0000000027764c41 14. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:222: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x0000000027b97730 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 @ 0x0000000027aa00db 16. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:0: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x000000002c7b254b 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7eb79e 18. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:118: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7c9d8a 19. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x000000002c7e0473 20. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x000000002c7dbec3 21. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:0: DB::MergeTreeReadTask::read(DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002c82d05b 22. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:53: DB::MergeTreeInOrderSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&, DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002dea5374 23. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:0: DB::MergeTreeSelectProcessor::read() @ 0x000000002c8242f9 24. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000002de6d77a 25. ./build_docker/./src/Processors/ISource.cpp:0: DB::ISource::work() @ 0x000000002d3290a1 26. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 27. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 28. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 29. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 30. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 31. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 2025.09.09 15:06:57.402514 [ 20161 ] {} DatabaseCatalog: Cannot drop table test_0473czib.mt (37fd3cf2-879f-4934-ac8d-662471988a31). Will retry later.: 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af80b71 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80746 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000263a174e 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002c47c445 8. ./contrib/llvm-project/libcxx/include/vector:547: DB::MergeTreeData::clearPartsFromFilesystem(std::vector, std::allocator>> const&, bool, std::unordered_set, std::equal_to, std::allocator>*) @ 0x000000002c47a78e 9. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::dropAllData() @ 0x000000002c4862d9 10. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::dropTableFinally(DB::DatabaseCatalog::TableMarkedAsDropped const&) @ 0x00000000286c7c77 11. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: void std::__function::__policy_invoker::__call_impl, std::allocator>>)::$_0, void ()>>(std::__function::__policy_storage const*) @ 0x00000000286d9744 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000263a3ea5 13. ./contrib/llvm-project/libcxx/include/future:0: std::packaged_task::operator()() @ 0x000000001bba33ac 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7eaf0 15. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001af8a79f 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 18. asan_thread_start(void*) @ 0x000000000aa43059 19. ? @ 0x00007f35aab92ac3 20. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:06:57.477628 [ 20343 ] {07f2d65d-6be5-41c2-b84e-fcc654b85579} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=9, jobs=0): (while reading column key_column): (while reading from part /var/lib/clickhouse/store/cab/cabf9a66-80e2-4148-8335-3c53187f5a8a/all_1_1_0/ in table database_for_dict.table_for_dict (cabf9a66-80e2-4148-8335-3c53187f5a8a) located on disk default of type local, from mark 0 with max_rows_to_read = 1): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder): while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:60722) (comment: 01542_dictionary_load_exception_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af80b71 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80746 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000266005a2 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000265fffb4 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:1197: ? @ 0x00000000265fd4e7 9. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:62: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x00000000265e6fbd 10. ./contrib/llvm-project/libcxx/include/future:1123: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x00000000265e7bb3 11. DB::ReadBuffer::next() @ 0x000000000b528aeb 12. ./src/IO/ReadBuffer.h:0: DB::CompressedReadBufferBase::readCompressedDataBlockForAsynchronous(unsigned long&, unsigned long&) @ 0x0000000027760e7f 13. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:110: DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x0000000027764c41 14. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:222: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x0000000027b97730 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 @ 0x0000000027aa00db 16. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:0: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x000000002c7b254b 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7eb79e 18. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:118: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7c9d8a 19. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x000000002c7e0473 20. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x000000002c7dbec3 21. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:0: DB::MergeTreeReadTask::read(DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002c82d05b 22. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:53: DB::MergeTreeInOrderSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&, DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002dea5374 23. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:0: DB::MergeTreeSelectProcessor::read() @ 0x000000002c8242f9 24. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000002de6d77a 25. ./build_docker/./src/Processors/ISource.cpp:0: DB::ISource::work() @ 0x000000002d3290a1 26. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 27. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 28. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 29. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 30. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 31. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 2025.09.09 15:06:57.486405 [ 20343 ] {07f2d65d-6be5-41c2-b84e-fcc654b85579} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=9, jobs=0): (while reading column key_column): (while reading from part /var/lib/clickhouse/store/cab/cabf9a66-80e2-4148-8335-3c53187f5a8a/all_1_1_0/ in table database_for_dict.table_for_dict (cabf9a66-80e2-4148-8335-3c53187f5a8a) located on disk default of type local, from mark 0 with max_rows_to_read = 1): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder): while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af80b71 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80746 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000266005a2 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000265fffb4 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:1197: ? @ 0x00000000265fd4e7 9. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:62: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x00000000265e6fbd 10. ./contrib/llvm-project/libcxx/include/future:1123: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x00000000265e7bb3 11. DB::ReadBuffer::next() @ 0x000000000b528aeb 12. ./src/IO/ReadBuffer.h:0: DB::CompressedReadBufferBase::readCompressedDataBlockForAsynchronous(unsigned long&, unsigned long&) @ 0x0000000027760e7f 13. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:110: DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x0000000027764c41 14. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:222: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x0000000027b97730 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 @ 0x0000000027aa00db 16. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:0: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x000000002c7b254b 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7eb79e 18. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:118: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7c9d8a 19. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x000000002c7e0473 20. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x000000002c7dbec3 21. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:0: DB::MergeTreeReadTask::read(DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002c82d05b 22. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:53: DB::MergeTreeInOrderSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&, DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002dea5374 23. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:0: DB::MergeTreeSelectProcessor::read() @ 0x000000002c8242f9 24. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000002de6d77a 25. ./build_docker/./src/Processors/ISource.cpp:0: DB::ISource::work() @ 0x000000002d3290a1 26. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 27. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 28. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 29. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 30. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 31. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 2025.09.09 15:06:57.509557 [ 3026 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:06:57.510633 [ 3014 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:06:57.609277 [ 3000 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:06:57.645102 [ 20350 ] {4afe1ab8-1dab-4ed7-819d-e2b8fb16e6f0} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=9, jobs=0): (while reading column key_column): (while reading from part /var/lib/clickhouse/store/cab/cabf9a66-80e2-4148-8335-3c53187f5a8a/all_1_1_0/ in table database_for_dict.table_for_dict (cabf9a66-80e2-4148-8335-3c53187f5a8a) located on disk default of type local, from mark 0 with max_rows_to_read = 1): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder): while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:60732) (comment: 01542_dictionary_load_exception_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af80b71 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80746 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000266005a2 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000265fffb4 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:1197: ? @ 0x00000000265fd4e7 9. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:62: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x00000000265e6fbd 10. ./contrib/llvm-project/libcxx/include/future:1123: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x00000000265e7bb3 11. DB::ReadBuffer::next() @ 0x000000000b528aeb 12. ./src/IO/ReadBuffer.h:0: DB::CompressedReadBufferBase::readCompressedDataBlockForAsynchronous(unsigned long&, unsigned long&) @ 0x0000000027760e7f 13. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:110: DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x0000000027764c41 14. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:222: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x0000000027b97730 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 @ 0x0000000027aa00db 16. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:0: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x000000002c7b254b 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7eb79e 18. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:118: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7c9d8a 19. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x000000002c7e0473 20. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x000000002c7dbec3 21. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:0: DB::MergeTreeReadTask::read(DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002c82d05b 22. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:53: DB::MergeTreeInOrderSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&, DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002dea5374 23. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:0: DB::MergeTreeSelectProcessor::read() @ 0x000000002c8242f9 24. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000002de6d77a 25. ./build_docker/./src/Processors/ISource.cpp:0: DB::ISource::work() @ 0x000000002d3290a1 26. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 27. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 28. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 29. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 30. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 31. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 2025.09.09 15:06:57.654748 [ 20350 ] {4afe1ab8-1dab-4ed7-819d-e2b8fb16e6f0} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=9, jobs=0): (while reading column key_column): (while reading from part /var/lib/clickhouse/store/cab/cabf9a66-80e2-4148-8335-3c53187f5a8a/all_1_1_0/ in table database_for_dict.table_for_dict (cabf9a66-80e2-4148-8335-3c53187f5a8a) located on disk default of type local, from mark 0 with max_rows_to_read = 1): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder): while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af80b71 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80746 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000266005a2 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000265fffb4 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:1197: ? @ 0x00000000265fd4e7 9. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:62: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x00000000265e6fbd 10. ./contrib/llvm-project/libcxx/include/future:1123: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x00000000265e7bb3 11. DB::ReadBuffer::next() @ 0x000000000b528aeb 12. ./src/IO/ReadBuffer.h:0: DB::CompressedReadBufferBase::readCompressedDataBlockForAsynchronous(unsigned long&, unsigned long&) @ 0x0000000027760e7f 13. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:110: DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x0000000027764c41 14. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:222: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x0000000027b97730 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 @ 0x0000000027aa00db 16. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:0: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x000000002c7b254b 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7eb79e 18. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:118: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7c9d8a 19. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x000000002c7e0473 20. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x000000002c7dbec3 21. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:0: DB::MergeTreeReadTask::read(DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002c82d05b 22. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:53: DB::MergeTreeInOrderSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&, DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002dea5374 23. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:0: DB::MergeTreeSelectProcessor::read() @ 0x000000002c8242f9 24. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000002de6d77a 25. ./build_docker/./src/Processors/ISource.cpp:0: DB::ISource::work() @ 0x000000002d3290a1 26. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 27. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 28. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 29. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 30. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 31. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 2025.09.09 15:06:57.736375 [ 20397 ] {2aa7db04-7614-4b35-bc57-644461650f81} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=9, jobs=0): (while reading column key_column): (while reading from part /var/lib/clickhouse/store/cab/cabf9a66-80e2-4148-8335-3c53187f5a8a/all_1_1_0/ in table database_for_dict.table_for_dict (cabf9a66-80e2-4148-8335-3c53187f5a8a) located on disk default of type local, from mark 0 with max_rows_to_read = 1): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder): while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:60744) (comment: 01542_dictionary_load_exception_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af80b71 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80746 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000266005a2 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000265fffb4 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:1197: ? @ 0x00000000265fd4e7 9. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:62: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x00000000265e6fbd 10. ./contrib/llvm-project/libcxx/include/future:1123: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x00000000265e7bb3 11. DB::ReadBuffer::next() @ 0x000000000b528aeb 12. ./src/IO/ReadBuffer.h:0: DB::CompressedReadBufferBase::readCompressedDataBlockForAsynchronous(unsigned long&, unsigned long&) @ 0x0000000027760e7f 13. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:110: DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x0000000027764c41 14. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:222: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x0000000027b97730 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 @ 0x0000000027aa00db 16. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:0: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x000000002c7b254b 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7eb79e 18. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:118: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7c9d8a 19. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x000000002c7e0473 20. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x000000002c7dbec3 21. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:0: DB::MergeTreeReadTask::read(DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002c82d05b 22. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:53: DB::MergeTreeInOrderSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&, DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002dea5374 23. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:0: DB::MergeTreeSelectProcessor::read() @ 0x000000002c8242f9 24. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000002de6d77a 25. ./build_docker/./src/Processors/ISource.cpp:0: DB::ISource::work() @ 0x000000002d3290a1 26. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 27. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 28. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 29. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 30. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 31. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 2025.09.09 15:06:57.739449 [ 20397 ] {2aa7db04-7614-4b35-bc57-644461650f81} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=9, jobs=0): (while reading column key_column): (while reading from part /var/lib/clickhouse/store/cab/cabf9a66-80e2-4148-8335-3c53187f5a8a/all_1_1_0/ in table database_for_dict.table_for_dict (cabf9a66-80e2-4148-8335-3c53187f5a8a) located on disk default of type local, from mark 0 with max_rows_to_read = 1): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder): while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af80b71 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80746 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000266005a2 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000265fffb4 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:1197: ? @ 0x00000000265fd4e7 9. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:62: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x00000000265e6fbd 10. ./contrib/llvm-project/libcxx/include/future:1123: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x00000000265e7bb3 11. DB::ReadBuffer::next() @ 0x000000000b528aeb 12. ./src/IO/ReadBuffer.h:0: DB::CompressedReadBufferBase::readCompressedDataBlockForAsynchronous(unsigned long&, unsigned long&) @ 0x0000000027760e7f 13. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:110: DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x0000000027764c41 14. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:222: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x0000000027b97730 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 @ 0x0000000027aa00db 16. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:0: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x000000002c7b254b 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7eb79e 18. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:118: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7c9d8a 19. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x000000002c7e0473 20. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x000000002c7dbec3 21. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:0: DB::MergeTreeReadTask::read(DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002c82d05b 22. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:53: DB::MergeTreeInOrderSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&, DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002dea5374 23. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:0: DB::MergeTreeSelectProcessor::read() @ 0x000000002c8242f9 24. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000002de6d77a 25. ./build_docker/./src/Processors/ISource.cpp:0: DB::ISource::work() @ 0x000000002d3290a1 26. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 27. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 28. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 29. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 30. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 31. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 2025.09.09 15:06:57.761864 [ 20379 ] {d0dac65f-28b3-42c3-8dd7-00ae431f9591} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=9, jobs=0): (while reading column key_column): (while reading from part /var/lib/clickhouse/store/cab/cabf9a66-80e2-4148-8335-3c53187f5a8a/all_1_1_0/ in table database_for_dict.table_for_dict (cabf9a66-80e2-4148-8335-3c53187f5a8a) located on disk default of type local, from mark 0 with max_rows_to_read = 1): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder): while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:60784) (comment: 01542_dictionary_load_exception_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af80b71 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80746 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000266005a2 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000265fffb4 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:1197: ? @ 0x00000000265fd4e7 9. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:62: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x00000000265e6fbd 10. ./contrib/llvm-project/libcxx/include/future:1123: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x00000000265e7bb3 11. DB::ReadBuffer::next() @ 0x000000000b528aeb 12. ./src/IO/ReadBuffer.h:0: DB::CompressedReadBufferBase::readCompressedDataBlockForAsynchronous(unsigned long&, unsigned long&) @ 0x0000000027760e7f 13. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:110: DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x0000000027764c41 14. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:222: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x0000000027b97730 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 @ 0x0000000027aa00db 16. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:0: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x000000002c7b254b 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7eb79e 18. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:118: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7c9d8a 19. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x000000002c7e0473 20. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x000000002c7dbec3 21. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:0: DB::MergeTreeReadTask::read(DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002c82d05b 22. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:53: DB::MergeTreeInOrderSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&, DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002dea5374 23. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:0: DB::MergeTreeSelectProcessor::read() @ 0x000000002c8242f9 24. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000002de6d77a 25. ./build_docker/./src/Processors/ISource.cpp:0: DB::ISource::work() @ 0x000000002d3290a1 26. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 27. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 28. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 29. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 30. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 31. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 2025.09.09 15:06:57.762024 [ 20353 ] {a05b99d8-79fb-478f-84c5-3649f58f0bf5} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=9, jobs=0): (while reading column key_column): (while reading from part /var/lib/clickhouse/store/cab/cabf9a66-80e2-4148-8335-3c53187f5a8a/all_1_1_0/ in table database_for_dict.table_for_dict (cabf9a66-80e2-4148-8335-3c53187f5a8a) located on disk default of type local, from mark 0 with max_rows_to_read = 1): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder): while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:60760) (comment: 01542_dictionary_load_exception_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af80b71 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80746 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000266005a2 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000265fffb4 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:1197: ? @ 0x00000000265fd4e7 9. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:62: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x00000000265e6fbd 10. ./contrib/llvm-project/libcxx/include/future:1123: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x00000000265e7bb3 11. DB::ReadBuffer::next() @ 0x000000000b528aeb 12. ./src/IO/ReadBuffer.h:0: DB::CompressedReadBufferBase::readCompressedDataBlockForAsynchronous(unsigned long&, unsigned long&) @ 0x0000000027760e7f 13. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:110: DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x0000000027764c41 14. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:222: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x0000000027b97730 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 @ 0x0000000027aa00db 16. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:0: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x000000002c7b254b 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7eb79e 18. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:118: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7c9d8a 19. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x000000002c7e0473 20. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x000000002c7dbec3 21. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:0: DB::MergeTreeReadTask::read(DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002c82d05b 22. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:53: DB::MergeTreeInOrderSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&, DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002dea5374 23. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:0: DB::MergeTreeSelectProcessor::read() @ 0x000000002c8242f9 24. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000002de6d77a 25. ./build_docker/./src/Processors/ISource.cpp:0: DB::ISource::work() @ 0x000000002d3290a1 26. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 27. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 28. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 29. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 30. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 31. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 2025.09.09 15:06:57.767095 [ 20353 ] {a05b99d8-79fb-478f-84c5-3649f58f0bf5} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=9, jobs=0): (while reading column key_column): (while reading from part /var/lib/clickhouse/store/cab/cabf9a66-80e2-4148-8335-3c53187f5a8a/all_1_1_0/ in table database_for_dict.table_for_dict (cabf9a66-80e2-4148-8335-3c53187f5a8a) located on disk default of type local, from mark 0 with max_rows_to_read = 1): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder): while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af80b71 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80746 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000266005a2 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000265fffb4 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:1197: ? @ 0x00000000265fd4e7 9. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:62: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x00000000265e6fbd 10. ./contrib/llvm-project/libcxx/include/future:1123: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x00000000265e7bb3 11. DB::ReadBuffer::next() @ 0x000000000b528aeb 12. ./src/IO/ReadBuffer.h:0: DB::CompressedReadBufferBase::readCompressedDataBlockForAsynchronous(unsigned long&, unsigned long&) @ 0x0000000027760e7f 13. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:110: DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x0000000027764c41 14. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:222: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x0000000027b97730 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 @ 0x0000000027aa00db 16. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:0: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x000000002c7b254b 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7eb79e 18. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:118: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7c9d8a 19. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x000000002c7e0473 20. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x000000002c7dbec3 21. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:0: DB::MergeTreeReadTask::read(DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002c82d05b 22. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:53: DB::MergeTreeInOrderSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&, DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002dea5374 23. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:0: DB::MergeTreeSelectProcessor::read() @ 0x000000002c8242f9 24. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000002de6d77a 25. ./build_docker/./src/Processors/ISource.cpp:0: DB::ISource::work() @ 0x000000002d3290a1 26. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 27. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 28. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 29. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 30. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 31. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 2025.09.09 15:06:57.771457 [ 20379 ] {d0dac65f-28b3-42c3-8dd7-00ae431f9591} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=9, jobs=0): (while reading column key_column): (while reading from part /var/lib/clickhouse/store/cab/cabf9a66-80e2-4148-8335-3c53187f5a8a/all_1_1_0/ in table database_for_dict.table_for_dict (cabf9a66-80e2-4148-8335-3c53187f5a8a) located on disk default of type local, from mark 0 with max_rows_to_read = 1): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder): while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af80b71 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80746 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000266005a2 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000265fffb4 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:1197: ? @ 0x00000000265fd4e7 9. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:62: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x00000000265e6fbd 10. ./contrib/llvm-project/libcxx/include/future:1123: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x00000000265e7bb3 11. DB::ReadBuffer::next() @ 0x000000000b528aeb 12. ./src/IO/ReadBuffer.h:0: DB::CompressedReadBufferBase::readCompressedDataBlockForAsynchronous(unsigned long&, unsigned long&) @ 0x0000000027760e7f 13. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:110: DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x0000000027764c41 14. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:222: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x0000000027b97730 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 @ 0x0000000027aa00db 16. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:0: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x000000002c7b254b 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7eb79e 18. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:118: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7c9d8a 19. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x000000002c7e0473 20. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x000000002c7dbec3 21. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:0: DB::MergeTreeReadTask::read(DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002c82d05b 22. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:53: DB::MergeTreeInOrderSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&, DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002dea5374 23. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:0: DB::MergeTreeSelectProcessor::read() @ 0x000000002c8242f9 24. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000002de6d77a 25. ./build_docker/./src/Processors/ISource.cpp:0: DB::ISource::work() @ 0x000000002d3290a1 26. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 27. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 28. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 29. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 30. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 31. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 2025.09.09 15:06:57.781301 [ 20351 ] {5a6218b0-7b0e-4155-b09a-b1fa7a7a1f3b} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=9, jobs=0): (while reading column key_column): (while reading from part /var/lib/clickhouse/store/cab/cabf9a66-80e2-4148-8335-3c53187f5a8a/all_1_1_0/ in table database_for_dict.table_for_dict (cabf9a66-80e2-4148-8335-3c53187f5a8a) located on disk default of type local, from mark 0 with max_rows_to_read = 1): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder): while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:60748) (comment: 01542_dictionary_load_exception_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af80b71 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80746 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000266005a2 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000265fffb4 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:1197: ? @ 0x00000000265fd4e7 9. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:62: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x00000000265e6fbd 10. ./contrib/llvm-project/libcxx/include/future:1123: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x00000000265e7bb3 11. DB::ReadBuffer::next() @ 0x000000000b528aeb 12. ./src/IO/ReadBuffer.h:0: DB::CompressedReadBufferBase::readCompressedDataBlockForAsynchronous(unsigned long&, unsigned long&) @ 0x0000000027760e7f 13. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:110: DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x0000000027764c41 14. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:222: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x0000000027b97730 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 @ 0x0000000027aa00db 16. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:0: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x000000002c7b254b 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7eb79e 18. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:118: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7c9d8a 19. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x000000002c7e0473 20. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x000000002c7dbec3 21. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:0: DB::MergeTreeReadTask::read(DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002c82d05b 22. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:53: DB::MergeTreeInOrderSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&, DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002dea5374 23. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:0: DB::MergeTreeSelectProcessor::read() @ 0x000000002c8242f9 24. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000002de6d77a 25. ./build_docker/./src/Processors/ISource.cpp:0: DB::ISource::work() @ 0x000000002d3290a1 26. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 27. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 28. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 29. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 30. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 31. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 2025.09.09 15:06:57.787660 [ 20351 ] {5a6218b0-7b0e-4155-b09a-b1fa7a7a1f3b} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=9, jobs=0): (while reading column key_column): (while reading from part /var/lib/clickhouse/store/cab/cabf9a66-80e2-4148-8335-3c53187f5a8a/all_1_1_0/ in table database_for_dict.table_for_dict (cabf9a66-80e2-4148-8335-3c53187f5a8a) located on disk default of type local, from mark 0 with max_rows_to_read = 1): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder): while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af80b71 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80746 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000266005a2 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000265fffb4 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:1197: ? @ 0x00000000265fd4e7 9. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:62: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x00000000265e6fbd 10. ./contrib/llvm-project/libcxx/include/future:1123: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x00000000265e7bb3 11. DB::ReadBuffer::next() @ 0x000000000b528aeb 12. ./src/IO/ReadBuffer.h:0: DB::CompressedReadBufferBase::readCompressedDataBlockForAsynchronous(unsigned long&, unsigned long&) @ 0x0000000027760e7f 13. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:110: DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x0000000027764c41 14. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:222: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x0000000027b97730 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 @ 0x0000000027aa00db 16. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:0: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x000000002c7b254b 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7eb79e 18. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:118: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7c9d8a 19. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x000000002c7e0473 20. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x000000002c7dbec3 21. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:0: DB::MergeTreeReadTask::read(DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002c82d05b 22. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:53: DB::MergeTreeInOrderSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&, DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002dea5374 23. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:0: DB::MergeTreeSelectProcessor::read() @ 0x000000002c8242f9 24. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000002de6d77a 25. ./build_docker/./src/Processors/ISource.cpp:0: DB::ISource::work() @ 0x000000002d3290a1 26. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 27. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 28. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 29. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 30. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 31. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 2025.09.09 15:06:57.803769 [ 20355 ] {989a6f78-14cc-4526-a1e4-6bd474de1cd3} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=9, jobs=0): (while reading column key_column): (while reading from part /var/lib/clickhouse/store/cab/cabf9a66-80e2-4148-8335-3c53187f5a8a/all_1_1_0/ in table database_for_dict.table_for_dict (cabf9a66-80e2-4148-8335-3c53187f5a8a) located on disk default of type local, from mark 0 with max_rows_to_read = 1): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder): while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:60768) (comment: 01542_dictionary_load_exception_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af80b71 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80746 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000266005a2 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000265fffb4 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:1197: ? @ 0x00000000265fd4e7 9. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:62: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x00000000265e6fbd 10. ./contrib/llvm-project/libcxx/include/future:1123: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x00000000265e7bb3 11. DB::ReadBuffer::next() @ 0x000000000b528aeb 12. ./src/IO/ReadBuffer.h:0: DB::CompressedReadBufferBase::readCompressedDataBlockForAsynchronous(unsigned long&, unsigned long&) @ 0x0000000027760e7f 13. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:110: DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x0000000027764c41 14. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:222: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x0000000027b97730 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 @ 0x0000000027aa00db 16. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:0: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x000000002c7b254b 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7eb79e 18. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:118: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7c9d8a 19. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x000000002c7e0473 20. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x000000002c7dbec3 21. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:0: DB::MergeTreeReadTask::read(DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002c82d05b 22. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:53: DB::MergeTreeInOrderSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&, DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002dea5374 23. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:0: DB::MergeTreeSelectProcessor::read() @ 0x000000002c8242f9 24. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000002de6d77a 25. ./build_docker/./src/Processors/ISource.cpp:0: DB::ISource::work() @ 0x000000002d3290a1 26. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 27. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 28. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 29. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 30. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 31. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 2025.09.09 15:06:57.810553 [ 20355 ] {989a6f78-14cc-4526-a1e4-6bd474de1cd3} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=9, jobs=0): (while reading column key_column): (while reading from part /var/lib/clickhouse/store/cab/cabf9a66-80e2-4148-8335-3c53187f5a8a/all_1_1_0/ in table database_for_dict.table_for_dict (cabf9a66-80e2-4148-8335-3c53187f5a8a) located on disk default of type local, from mark 0 with max_rows_to_read = 1): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder): while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af80b71 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80746 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000266005a2 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000265fffb4 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:1197: ? @ 0x00000000265fd4e7 9. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:62: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x00000000265e6fbd 10. ./contrib/llvm-project/libcxx/include/future:1123: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x00000000265e7bb3 11. DB::ReadBuffer::next() @ 0x000000000b528aeb 12. ./src/IO/ReadBuffer.h:0: DB::CompressedReadBufferBase::readCompressedDataBlockForAsynchronous(unsigned long&, unsigned long&) @ 0x0000000027760e7f 13. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:110: DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x0000000027764c41 14. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:222: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x0000000027b97730 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 @ 0x0000000027aa00db 16. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:0: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x000000002c7b254b 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7eb79e 18. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:118: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7c9d8a 19. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x000000002c7e0473 20. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x000000002c7dbec3 21. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:0: DB::MergeTreeReadTask::read(DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002c82d05b 22. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:53: DB::MergeTreeInOrderSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&, DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002dea5374 23. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:0: DB::MergeTreeSelectProcessor::read() @ 0x000000002c8242f9 24. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000002de6d77a 25. ./build_docker/./src/Processors/ISource.cpp:0: DB::ISource::work() @ 0x000000002d3290a1 26. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 27. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 28. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 29. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 30. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 31. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 2025.09.09 15:06:57.845297 [ 20380 ] {c1a3b39f-a753-4248-b36e-c138e8e0b240} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=9, jobs=0): (while reading column key_column): (while reading from part /var/lib/clickhouse/store/cab/cabf9a66-80e2-4148-8335-3c53187f5a8a/all_1_1_0/ in table database_for_dict.table_for_dict (cabf9a66-80e2-4148-8335-3c53187f5a8a) located on disk default of type local, from mark 0 with max_rows_to_read = 1): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder): while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:60806) (comment: 01542_dictionary_load_exception_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af80b71 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80746 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000266005a2 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000265fffb4 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:1197: ? @ 0x00000000265fd4e7 9. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:62: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x00000000265e6fbd 10. ./contrib/llvm-project/libcxx/include/future:1123: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x00000000265e7bb3 11. DB::ReadBuffer::next() @ 0x000000000b528aeb 12. ./src/IO/ReadBuffer.h:0: DB::CompressedReadBufferBase::readCompressedDataBlockForAsynchronous(unsigned long&, unsigned long&) @ 0x0000000027760e7f 13. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:110: DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x0000000027764c41 14. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:222: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x0000000027b97730 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 @ 0x0000000027aa00db 16. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:0: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x000000002c7b254b 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7eb79e 18. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:118: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7c9d8a 19. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x000000002c7e0473 20. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x000000002c7dbec3 21. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:0: DB::MergeTreeReadTask::read(DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002c82d05b 22. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:53: DB::MergeTreeInOrderSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&, DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002dea5374 23. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:0: DB::MergeTreeSelectProcessor::read() @ 0x000000002c8242f9 24. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000002de6d77a 25. ./build_docker/./src/Processors/ISource.cpp:0: DB::ISource::work() @ 0x000000002d3290a1 26. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 27. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 28. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 29. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 30. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 31. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 2025.09.09 15:06:57.847228 [ 20380 ] {c1a3b39f-a753-4248-b36e-c138e8e0b240} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=9, jobs=0): (while reading column key_column): (while reading from part /var/lib/clickhouse/store/cab/cabf9a66-80e2-4148-8335-3c53187f5a8a/all_1_1_0/ in table database_for_dict.table_for_dict (cabf9a66-80e2-4148-8335-3c53187f5a8a) located on disk default of type local, from mark 0 with max_rows_to_read = 1): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder): while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af80b71 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80746 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000266005a2 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000265fffb4 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:1197: ? @ 0x00000000265fd4e7 9. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:62: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x00000000265e6fbd 10. ./contrib/llvm-project/libcxx/include/future:1123: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x00000000265e7bb3 11. DB::ReadBuffer::next() @ 0x000000000b528aeb 12. ./src/IO/ReadBuffer.h:0: DB::CompressedReadBufferBase::readCompressedDataBlockForAsynchronous(unsigned long&, unsigned long&) @ 0x0000000027760e7f 13. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:110: DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x0000000027764c41 14. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:222: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x0000000027b97730 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 @ 0x0000000027aa00db 16. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:0: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x000000002c7b254b 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7eb79e 18. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:118: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7c9d8a 19. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x000000002c7e0473 20. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x000000002c7dbec3 21. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:0: DB::MergeTreeReadTask::read(DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002c82d05b 22. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:53: DB::MergeTreeInOrderSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&, DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002dea5374 23. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:0: DB::MergeTreeSelectProcessor::read() @ 0x000000002c8242f9 24. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000002de6d77a 25. ./build_docker/./src/Processors/ISource.cpp:0: DB::ISource::work() @ 0x000000002d3290a1 26. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 27. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 28. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 29. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 30. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 31. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 2025.09.09 15:06:57.985222 [ 19252 ] {10199e6d-2b21-490b-9776-35e8158adf6e} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=9, jobs=0): (while reading column key_column): (while reading from part /var/lib/clickhouse/store/cab/cabf9a66-80e2-4148-8335-3c53187f5a8a/all_1_1_0/ in table database_for_dict.table_for_dict (cabf9a66-80e2-4148-8335-3c53187f5a8a) located on disk default of type local, from mark 0 with max_rows_to_read = 1): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder): while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:60814) (comment: 01542_dictionary_load_exception_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af80b71 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80746 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000266005a2 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000265fffb4 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:1197: ? @ 0x00000000265fd4e7 9. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:62: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x00000000265e6fbd 10. ./contrib/llvm-project/libcxx/include/future:1123: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x00000000265e7bb3 11. DB::ReadBuffer::next() @ 0x000000000b528aeb 12. ./src/IO/ReadBuffer.h:0: DB::CompressedReadBufferBase::readCompressedDataBlockForAsynchronous(unsigned long&, unsigned long&) @ 0x0000000027760e7f 13. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:110: DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x0000000027764c41 14. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:222: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x0000000027b97730 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 @ 0x0000000027aa00db 16. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:0: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x000000002c7b254b 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7eb79e 18. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:118: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7c9d8a 19. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x000000002c7e0473 20. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x000000002c7dbec3 21. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:0: DB::MergeTreeReadTask::read(DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002c82d05b 22. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:53: DB::MergeTreeInOrderSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&, DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002dea5374 23. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:0: DB::MergeTreeSelectProcessor::read() @ 0x000000002c8242f9 24. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000002de6d77a 25. ./build_docker/./src/Processors/ISource.cpp:0: DB::ISource::work() @ 0x000000002d3290a1 26. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 27. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 28. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 29. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 30. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 31. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 2025.09.09 15:06:57.997648 [ 19252 ] {10199e6d-2b21-490b-9776-35e8158adf6e} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=9, jobs=0): (while reading column key_column): (while reading from part /var/lib/clickhouse/store/cab/cabf9a66-80e2-4148-8335-3c53187f5a8a/all_1_1_0/ in table database_for_dict.table_for_dict (cabf9a66-80e2-4148-8335-3c53187f5a8a) located on disk default of type local, from mark 0 with max_rows_to_read = 1): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder): while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af80b71 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80746 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000266005a2 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000265fffb4 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:1197: ? @ 0x00000000265fd4e7 9. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:62: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x00000000265e6fbd 10. ./contrib/llvm-project/libcxx/include/future:1123: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x00000000265e7bb3 11. DB::ReadBuffer::next() @ 0x000000000b528aeb 12. ./src/IO/ReadBuffer.h:0: DB::CompressedReadBufferBase::readCompressedDataBlockForAsynchronous(unsigned long&, unsigned long&) @ 0x0000000027760e7f 13. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:110: DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x0000000027764c41 14. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:222: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x0000000027b97730 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 @ 0x0000000027aa00db 16. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:0: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x000000002c7b254b 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7eb79e 18. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:118: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7c9d8a 19. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x000000002c7e0473 20. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x000000002c7dbec3 21. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:0: DB::MergeTreeReadTask::read(DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002c82d05b 22. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:53: DB::MergeTreeInOrderSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&, DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002dea5374 23. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:0: DB::MergeTreeSelectProcessor::read() @ 0x000000002c8242f9 24. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000002de6d77a 25. ./build_docker/./src/Processors/ISource.cpp:0: DB::ISource::work() @ 0x000000002d3290a1 26. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 27. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 28. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 29. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 30. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 31. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 2025.09.09 15:06:58.006717 [ 20849 ] {87cef776-2146-4422-98c1-2bee6e68b370} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=9, jobs=0): (while reading column key_column): (while reading from part /var/lib/clickhouse/store/cab/cabf9a66-80e2-4148-8335-3c53187f5a8a/all_1_1_0/ in table database_for_dict.table_for_dict (cabf9a66-80e2-4148-8335-3c53187f5a8a) located on disk default of type local, from mark 0 with max_rows_to_read = 1): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder): while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:60816) (comment: 01542_dictionary_load_exception_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af80b71 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80746 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000266005a2 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000265fffb4 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:1197: ? @ 0x00000000265fd4e7 9. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:62: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x00000000265e6fbd 10. ./contrib/llvm-project/libcxx/include/future:1123: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x00000000265e7bb3 11. DB::ReadBuffer::next() @ 0x000000000b528aeb 12. ./src/IO/ReadBuffer.h:0: DB::CompressedReadBufferBase::readCompressedDataBlockForAsynchronous(unsigned long&, unsigned long&) @ 0x0000000027760e7f 13. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:110: DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x0000000027764c41 14. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:222: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x0000000027b97730 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 @ 0x0000000027aa00db 16. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:0: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x000000002c7b254b 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7eb79e 18. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:118: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7c9d8a 19. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x000000002c7e0473 20. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x000000002c7dbec3 21. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:0: DB::MergeTreeReadTask::read(DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002c82d05b 22. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:53: DB::MergeTreeInOrderSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&, DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002dea5374 23. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:0: DB::MergeTreeSelectProcessor::read() @ 0x000000002c8242f9 24. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000002de6d77a 25. ./build_docker/./src/Processors/ISource.cpp:0: DB::ISource::work() @ 0x000000002d3290a1 26. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 27. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 28. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 29. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 30. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 31. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 2025.09.09 15:06:58.020237 [ 20345 ] {7e0d5d31-ae0a-441e-9d2d-e5fb4cc596fa} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=9, jobs=0): (while reading column key_column): (while reading from part /var/lib/clickhouse/store/cab/cabf9a66-80e2-4148-8335-3c53187f5a8a/all_1_1_0/ in table database_for_dict.table_for_dict (cabf9a66-80e2-4148-8335-3c53187f5a8a) located on disk default of type local, from mark 0 with max_rows_to_read = 1): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder): while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:60800) (comment: 01542_dictionary_load_exception_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af80b71 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80746 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000266005a2 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000265fffb4 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:1197: ? @ 0x00000000265fd4e7 9. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:62: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x00000000265e6fbd 10. ./contrib/llvm-project/libcxx/include/future:1123: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x00000000265e7bb3 11. DB::ReadBuffer::next() @ 0x000000000b528aeb 12. ./src/IO/ReadBuffer.h:0: DB::CompressedReadBufferBase::readCompressedDataBlockForAsynchronous(unsigned long&, unsigned long&) @ 0x0000000027760e7f 13. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:110: DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x0000000027764c41 14. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:222: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x0000000027b97730 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 @ 0x0000000027aa00db 16. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:0: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x000000002c7b254b 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7eb79e 18. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:118: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7c9d8a 19. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x000000002c7e0473 20. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x000000002c7dbec3 21. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:0: DB::MergeTreeReadTask::read(DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002c82d05b 22. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:53: DB::MergeTreeInOrderSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&, DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002dea5374 23. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:0: DB::MergeTreeSelectProcessor::read() @ 0x000000002c8242f9 24. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000002de6d77a 25. ./build_docker/./src/Processors/ISource.cpp:0: DB::ISource::work() @ 0x000000002d3290a1 26. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 27. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 28. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 29. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 30. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 31. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 2025.09.09 15:06:58.022795 [ 20849 ] {87cef776-2146-4422-98c1-2bee6e68b370} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=9, jobs=0): (while reading column key_column): (while reading from part /var/lib/clickhouse/store/cab/cabf9a66-80e2-4148-8335-3c53187f5a8a/all_1_1_0/ in table database_for_dict.table_for_dict (cabf9a66-80e2-4148-8335-3c53187f5a8a) located on disk default of type local, from mark 0 with max_rows_to_read = 1): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder): while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af80b71 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80746 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000266005a2 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000265fffb4 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:1197: ? @ 0x00000000265fd4e7 9. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:62: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x00000000265e6fbd 10. ./contrib/llvm-project/libcxx/include/future:1123: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x00000000265e7bb3 11. DB::ReadBuffer::next() @ 0x000000000b528aeb 12. ./src/IO/ReadBuffer.h:0: DB::CompressedReadBufferBase::readCompressedDataBlockForAsynchronous(unsigned long&, unsigned long&) @ 0x0000000027760e7f 13. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:110: DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x0000000027764c41 14. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:222: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x0000000027b97730 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 @ 0x0000000027aa00db 16. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:0: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x000000002c7b254b 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7eb79e 18. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:118: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7c9d8a 19. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x000000002c7e0473 20. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x000000002c7dbec3 21. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:0: DB::MergeTreeReadTask::read(DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002c82d05b 22. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:53: DB::MergeTreeInOrderSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&, DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002dea5374 23. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:0: DB::MergeTreeSelectProcessor::read() @ 0x000000002c8242f9 24. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000002de6d77a 25. ./build_docker/./src/Processors/ISource.cpp:0: DB::ISource::work() @ 0x000000002d3290a1 26. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 27. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 28. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 29. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 30. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 31. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 2025.09.09 15:06:58.030541 [ 20345 ] {7e0d5d31-ae0a-441e-9d2d-e5fb4cc596fa} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=9, jobs=0): (while reading column key_column): (while reading from part /var/lib/clickhouse/store/cab/cabf9a66-80e2-4148-8335-3c53187f5a8a/all_1_1_0/ in table database_for_dict.table_for_dict (cabf9a66-80e2-4148-8335-3c53187f5a8a) located on disk default of type local, from mark 0 with max_rows_to_read = 1): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder): while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af80b71 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80746 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000266005a2 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000265fffb4 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:1197: ? @ 0x00000000265fd4e7 9. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:62: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x00000000265e6fbd 10. ./contrib/llvm-project/libcxx/include/future:1123: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x00000000265e7bb3 11. DB::ReadBuffer::next() @ 0x000000000b528aeb 12. ./src/IO/ReadBuffer.h:0: DB::CompressedReadBufferBase::readCompressedDataBlockForAsynchronous(unsigned long&, unsigned long&) @ 0x0000000027760e7f 13. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:110: DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x0000000027764c41 14. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:222: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x0000000027b97730 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 @ 0x0000000027aa00db 16. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:0: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x000000002c7b254b 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7eb79e 18. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:118: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7c9d8a 19. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x000000002c7e0473 20. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x000000002c7dbec3 21. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:0: DB::MergeTreeReadTask::read(DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002c82d05b 22. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:53: DB::MergeTreeInOrderSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&, DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002dea5374 23. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:0: DB::MergeTreeSelectProcessor::read() @ 0x000000002c8242f9 24. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000002de6d77a 25. ./build_docker/./src/Processors/ISource.cpp:0: DB::ISource::work() @ 0x000000002d3290a1 26. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 27. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 28. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 29. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 30. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 31. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 2025.09.09 15:06:58.153784 [ 3073 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:06:58.346588 [ 20881 ] {193f0ece-583b-499d-89f9-5835283617f6} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=9, jobs=0): (while reading column key_column): (while reading from part /var/lib/clickhouse/store/cab/cabf9a66-80e2-4148-8335-3c53187f5a8a/all_1_1_0/ in table database_for_dict.table_for_dict (cabf9a66-80e2-4148-8335-3c53187f5a8a) located on disk default of type local, from mark 0 with max_rows_to_read = 1): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder): while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:60824) (comment: 01542_dictionary_load_exception_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af80b71 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80746 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000266005a2 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000265fffb4 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:1197: ? @ 0x00000000265fd4e7 9. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:62: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x00000000265e6fbd 10. ./contrib/llvm-project/libcxx/include/future:1123: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x00000000265e7bb3 11. DB::ReadBuffer::next() @ 0x000000000b528aeb 12. ./src/IO/ReadBuffer.h:0: DB::CompressedReadBufferBase::readCompressedDataBlockForAsynchronous(unsigned long&, unsigned long&) @ 0x0000000027760e7f 13. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:110: DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x0000000027764c41 14. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:222: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x0000000027b97730 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 @ 0x0000000027aa00db 16. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:0: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x000000002c7b254b 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7eb79e 18. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:118: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7c9d8a 19. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x000000002c7e0473 20. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x000000002c7dbec3 21. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:0: DB::MergeTreeReadTask::read(DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002c82d05b 22. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:53: DB::MergeTreeInOrderSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&, DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002dea5374 23. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:0: DB::MergeTreeSelectProcessor::read() @ 0x000000002c8242f9 24. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000002de6d77a 25. ./build_docker/./src/Processors/ISource.cpp:0: DB::ISource::work() @ 0x000000002d3290a1 26. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 27. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 28. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 29. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 30. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 31. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 2025.09.09 15:06:58.362505 [ 20881 ] {193f0ece-583b-499d-89f9-5835283617f6} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=9, jobs=0): (while reading column key_column): (while reading from part /var/lib/clickhouse/store/cab/cabf9a66-80e2-4148-8335-3c53187f5a8a/all_1_1_0/ in table database_for_dict.table_for_dict (cabf9a66-80e2-4148-8335-3c53187f5a8a) located on disk default of type local, from mark 0 with max_rows_to_read = 1): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder): while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af80b71 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80746 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000266005a2 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000265fffb4 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:1197: ? @ 0x00000000265fd4e7 9. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:62: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x00000000265e6fbd 10. ./contrib/llvm-project/libcxx/include/future:1123: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x00000000265e7bb3 11. DB::ReadBuffer::next() @ 0x000000000b528aeb 12. ./src/IO/ReadBuffer.h:0: DB::CompressedReadBufferBase::readCompressedDataBlockForAsynchronous(unsigned long&, unsigned long&) @ 0x0000000027760e7f 13. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:110: DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x0000000027764c41 14. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:222: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x0000000027b97730 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 @ 0x0000000027aa00db 16. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:0: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x000000002c7b254b 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7eb79e 18. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:118: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7c9d8a 19. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x000000002c7e0473 20. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x000000002c7dbec3 21. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:0: DB::MergeTreeReadTask::read(DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002c82d05b 22. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:53: DB::MergeTreeInOrderSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&, DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002dea5374 23. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:0: DB::MergeTreeSelectProcessor::read() @ 0x000000002c8242f9 24. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000002de6d77a 25. ./build_docker/./src/Processors/ISource.cpp:0: DB::ISource::work() @ 0x000000002d3290a1 26. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 27. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 28. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 29. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 30. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 31. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 2025.09.09 15:06:58.511337 [ 3092 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:06:58.512531 [ 3102 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:06:58.528156 [ 19252 ] {1886923c-10b1-4a66-b561-1d1de101da2d} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=9, jobs=0): (while reading column key_column): (while reading from part /var/lib/clickhouse/store/cab/cabf9a66-80e2-4148-8335-3c53187f5a8a/all_1_1_0/ in table database_for_dict.table_for_dict (cabf9a66-80e2-4148-8335-3c53187f5a8a) located on disk default of type local, from mark 0 with max_rows_to_read = 1): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder): while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45174) (comment: 01542_dictionary_load_exception_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af80b71 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80746 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000266005a2 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000265fffb4 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:1197: ? @ 0x00000000265fd4e7 9. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:62: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x00000000265e6fbd 10. ./contrib/llvm-project/libcxx/include/future:1123: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x00000000265e7bb3 11. DB::ReadBuffer::next() @ 0x000000000b528aeb 12. ./src/IO/ReadBuffer.h:0: DB::CompressedReadBufferBase::readCompressedDataBlockForAsynchronous(unsigned long&, unsigned long&) @ 0x0000000027760e7f 13. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:110: DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x0000000027764c41 14. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:222: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x0000000027b97730 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 @ 0x0000000027aa00db 16. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:0: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x000000002c7b254b 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7eb79e 18. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:118: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7c9d8a 19. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x000000002c7e0473 20. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x000000002c7dbec3 21. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:0: DB::MergeTreeReadTask::read(DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002c82d05b 22. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:53: DB::MergeTreeInOrderSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&, DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002dea5374 23. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:0: DB::MergeTreeSelectProcessor::read() @ 0x000000002c8242f9 24. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000002de6d77a 25. ./build_docker/./src/Processors/ISource.cpp:0: DB::ISource::work() @ 0x000000002d3290a1 26. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 27. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 28. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 29. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 30. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 31. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 2025.09.09 15:06:58.530035 [ 19252 ] {1886923c-10b1-4a66-b561-1d1de101da2d} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=9, jobs=0): (while reading column key_column): (while reading from part /var/lib/clickhouse/store/cab/cabf9a66-80e2-4148-8335-3c53187f5a8a/all_1_1_0/ in table database_for_dict.table_for_dict (cabf9a66-80e2-4148-8335-3c53187f5a8a) located on disk default of type local, from mark 0 with max_rows_to_read = 1): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder): while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af80b71 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80746 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000266005a2 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000265fffb4 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:1197: ? @ 0x00000000265fd4e7 9. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:62: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x00000000265e6fbd 10. ./contrib/llvm-project/libcxx/include/future:1123: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x00000000265e7bb3 11. DB::ReadBuffer::next() @ 0x000000000b528aeb 12. ./src/IO/ReadBuffer.h:0: DB::CompressedReadBufferBase::readCompressedDataBlockForAsynchronous(unsigned long&, unsigned long&) @ 0x0000000027760e7f 13. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:110: DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x0000000027764c41 14. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:222: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x0000000027b97730 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 @ 0x0000000027aa00db 16. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:0: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x000000002c7b254b 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7eb79e 18. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:118: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7c9d8a 19. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x000000002c7e0473 20. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x000000002c7dbec3 21. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:0: DB::MergeTreeReadTask::read(DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002c82d05b 22. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:53: DB::MergeTreeInOrderSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&, DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002dea5374 23. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:0: DB::MergeTreeSelectProcessor::read() @ 0x000000002c8242f9 24. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000002de6d77a 25. ./build_docker/./src/Processors/ISource.cpp:0: DB::ISource::work() @ 0x000000002d3290a1 26. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 27. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 28. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 29. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 30. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 31. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 2025.09.09 15:06:58.547682 [ 20882 ] {d1d3acdb-a5bd-4489-b2cb-1458a139eb65} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=9, jobs=0): (while reading column key_column): (while reading from part /var/lib/clickhouse/store/cab/cabf9a66-80e2-4148-8335-3c53187f5a8a/all_1_1_0/ in table database_for_dict.table_for_dict (cabf9a66-80e2-4148-8335-3c53187f5a8a) located on disk default of type local, from mark 0 with max_rows_to_read = 1): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder): while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45188) (comment: 01542_dictionary_load_exception_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af80b71 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80746 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000266005a2 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000265fffb4 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:1197: ? @ 0x00000000265fd4e7 9. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:62: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x00000000265e6fbd 10. ./contrib/llvm-project/libcxx/include/future:1123: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x00000000265e7bb3 11. DB::ReadBuffer::next() @ 0x000000000b528aeb 12. ./src/IO/ReadBuffer.h:0: DB::CompressedReadBufferBase::readCompressedDataBlockForAsynchronous(unsigned long&, unsigned long&) @ 0x0000000027760e7f 13. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:110: DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x0000000027764c41 14. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:222: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x0000000027b97730 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 @ 0x0000000027aa00db 16. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:0: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x000000002c7b254b 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7eb79e 18. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:118: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7c9d8a 19. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x000000002c7e0473 20. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x000000002c7dbec3 21. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:0: DB::MergeTreeReadTask::read(DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002c82d05b 22. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:53: DB::MergeTreeInOrderSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&, DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002dea5374 23. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:0: DB::MergeTreeSelectProcessor::read() @ 0x000000002c8242f9 24. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000002de6d77a 25. ./build_docker/./src/Processors/ISource.cpp:0: DB::ISource::work() @ 0x000000002d3290a1 26. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 27. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 28. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 29. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 30. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 31. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 2025.09.09 15:06:58.550042 [ 20882 ] {d1d3acdb-a5bd-4489-b2cb-1458a139eb65} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=9, jobs=0): (while reading column key_column): (while reading from part /var/lib/clickhouse/store/cab/cabf9a66-80e2-4148-8335-3c53187f5a8a/all_1_1_0/ in table database_for_dict.table_for_dict (cabf9a66-80e2-4148-8335-3c53187f5a8a) located on disk default of type local, from mark 0 with max_rows_to_read = 1): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder): while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af80b71 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80746 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000266005a2 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000265fffb4 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:1197: ? @ 0x00000000265fd4e7 9. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:62: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x00000000265e6fbd 10. ./contrib/llvm-project/libcxx/include/future:1123: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x00000000265e7bb3 11. DB::ReadBuffer::next() @ 0x000000000b528aeb 12. ./src/IO/ReadBuffer.h:0: DB::CompressedReadBufferBase::readCompressedDataBlockForAsynchronous(unsigned long&, unsigned long&) @ 0x0000000027760e7f 13. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:110: DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x0000000027764c41 14. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:222: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x0000000027b97730 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 @ 0x0000000027aa00db 16. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:0: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x000000002c7b254b 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7eb79e 18. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:118: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7c9d8a 19. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x000000002c7e0473 20. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x000000002c7dbec3 21. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:0: DB::MergeTreeReadTask::read(DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002c82d05b 22. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:53: DB::MergeTreeInOrderSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&, DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002dea5374 23. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:0: DB::MergeTreeSelectProcessor::read() @ 0x000000002c8242f9 24. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000002de6d77a 25. ./build_docker/./src/Processors/ISource.cpp:0: DB::ISource::work() @ 0x000000002d3290a1 26. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 27. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 28. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 29. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 30. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 31. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 2025.09.09 15:06:58.565768 [ 2688 ] {abd6386a-0b5d-44f6-92e8-96934e363fb8} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=9, jobs=0): (while reading column key_column): (while reading from part /var/lib/clickhouse/store/cab/cabf9a66-80e2-4148-8335-3c53187f5a8a/all_1_1_0/ in table database_for_dict.table_for_dict (cabf9a66-80e2-4148-8335-3c53187f5a8a) located on disk default of type local, from mark 0 with max_rows_to_read = 1): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder): while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45220) (comment: 01542_dictionary_load_exception_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af80b71 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80746 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000266005a2 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000265fffb4 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:1197: ? @ 0x00000000265fd4e7 9. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:62: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x00000000265e6fbd 10. ./contrib/llvm-project/libcxx/include/future:1123: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x00000000265e7bb3 11. DB::ReadBuffer::next() @ 0x000000000b528aeb 12. ./src/IO/ReadBuffer.h:0: DB::CompressedReadBufferBase::readCompressedDataBlockForAsynchronous(unsigned long&, unsigned long&) @ 0x0000000027760e7f 13. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:110: DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x0000000027764c41 14. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:222: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x0000000027b97730 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 @ 0x0000000027aa00db 16. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:0: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x000000002c7b254b 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7eb79e 18. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:118: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7c9d8a 19. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x000000002c7e0473 20. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x000000002c7dbec3 21. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:0: DB::MergeTreeReadTask::read(DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002c82d05b 22. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:53: DB::MergeTreeInOrderSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&, DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002dea5374 23. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:0: DB::MergeTreeSelectProcessor::read() @ 0x000000002c8242f9 24. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000002de6d77a 25. ./build_docker/./src/Processors/ISource.cpp:0: DB::ISource::work() @ 0x000000002d3290a1 26. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 27. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 28. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 29. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 30. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 31. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 2025.09.09 15:06:58.576059 [ 2688 ] {abd6386a-0b5d-44f6-92e8-96934e363fb8} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=9, jobs=0): (while reading column key_column): (while reading from part /var/lib/clickhouse/store/cab/cabf9a66-80e2-4148-8335-3c53187f5a8a/all_1_1_0/ in table database_for_dict.table_for_dict (cabf9a66-80e2-4148-8335-3c53187f5a8a) located on disk default of type local, from mark 0 with max_rows_to_read = 1): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder): while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af80b71 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80746 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000266005a2 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000265fffb4 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:1197: ? @ 0x00000000265fd4e7 9. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:62: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x00000000265e6fbd 10. ./contrib/llvm-project/libcxx/include/future:1123: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x00000000265e7bb3 11. DB::ReadBuffer::next() @ 0x000000000b528aeb 12. ./src/IO/ReadBuffer.h:0: DB::CompressedReadBufferBase::readCompressedDataBlockForAsynchronous(unsigned long&, unsigned long&) @ 0x0000000027760e7f 13. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:110: DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x0000000027764c41 14. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:222: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x0000000027b97730 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 @ 0x0000000027aa00db 16. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:0: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x000000002c7b254b 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7eb79e 18. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:118: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7c9d8a 19. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x000000002c7e0473 20. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x000000002c7dbec3 21. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:0: DB::MergeTreeReadTask::read(DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002c82d05b 22. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:53: DB::MergeTreeInOrderSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&, DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002dea5374 23. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:0: DB::MergeTreeSelectProcessor::read() @ 0x000000002c8242f9 24. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000002de6d77a 25. ./build_docker/./src/Processors/ISource.cpp:0: DB::ISource::work() @ 0x000000002d3290a1 26. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 27. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 28. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 29. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 30. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 31. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 2025.09.09 15:06:58.589771 [ 3612 ] {79cab79c-a1af-472d-91d9-5622e33b3a0b} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=9, jobs=0): (while reading column key_column): (while reading from part /var/lib/clickhouse/store/cab/cabf9a66-80e2-4148-8335-3c53187f5a8a/all_1_1_0/ in table database_for_dict.table_for_dict (cabf9a66-80e2-4148-8335-3c53187f5a8a) located on disk default of type local, from mark 0 with max_rows_to_read = 1): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder): while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45214) (comment: 01542_dictionary_load_exception_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af80b71 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80746 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000266005a2 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000265fffb4 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:1197: ? @ 0x00000000265fd4e7 9. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:62: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x00000000265e6fbd 10. ./contrib/llvm-project/libcxx/include/future:1123: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x00000000265e7bb3 11. DB::ReadBuffer::next() @ 0x000000000b528aeb 12. ./src/IO/ReadBuffer.h:0: DB::CompressedReadBufferBase::readCompressedDataBlockForAsynchronous(unsigned long&, unsigned long&) @ 0x0000000027760e7f 13. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:110: DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x0000000027764c41 14. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:222: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x0000000027b97730 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 @ 0x0000000027aa00db 16. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:0: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x000000002c7b254b 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7eb79e 18. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:118: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7c9d8a 19. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x000000002c7e0473 20. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x000000002c7dbec3 21. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:0: DB::MergeTreeReadTask::read(DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002c82d05b 22. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:53: DB::MergeTreeInOrderSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&, DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002dea5374 23. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:0: DB::MergeTreeSelectProcessor::read() @ 0x000000002c8242f9 24. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000002de6d77a 25. ./build_docker/./src/Processors/ISource.cpp:0: DB::ISource::work() @ 0x000000002d3290a1 26. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 27. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 28. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 29. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 30. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 31. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 2025.09.09 15:06:58.591700 [ 3612 ] {79cab79c-a1af-472d-91d9-5622e33b3a0b} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=9, jobs=0): (while reading column key_column): (while reading from part /var/lib/clickhouse/store/cab/cabf9a66-80e2-4148-8335-3c53187f5a8a/all_1_1_0/ in table database_for_dict.table_for_dict (cabf9a66-80e2-4148-8335-3c53187f5a8a) located on disk default of type local, from mark 0 with max_rows_to_read = 1): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder): while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af80b71 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80746 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000266005a2 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000265fffb4 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:1197: ? @ 0x00000000265fd4e7 9. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:62: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x00000000265e6fbd 10. ./contrib/llvm-project/libcxx/include/future:1123: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x00000000265e7bb3 11. DB::ReadBuffer::next() @ 0x000000000b528aeb 12. ./src/IO/ReadBuffer.h:0: DB::CompressedReadBufferBase::readCompressedDataBlockForAsynchronous(unsigned long&, unsigned long&) @ 0x0000000027760e7f 13. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:110: DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x0000000027764c41 14. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:222: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x0000000027b97730 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 @ 0x0000000027aa00db 16. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:0: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x000000002c7b254b 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7eb79e 18. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:118: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7c9d8a 19. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x000000002c7e0473 20. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x000000002c7dbec3 21. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:0: DB::MergeTreeReadTask::read(DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002c82d05b 22. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:53: DB::MergeTreeInOrderSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&, DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002dea5374 23. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:0: DB::MergeTreeSelectProcessor::read() @ 0x000000002c8242f9 24. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000002de6d77a 25. ./build_docker/./src/Processors/ISource.cpp:0: DB::ISource::work() @ 0x000000002d3290a1 26. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 27. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 28. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 29. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 30. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 31. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 2025.09.09 15:06:58.611042 [ 3117 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:06:58.615537 [ 20884 ] {4834391a-d1a7-4c42-88f9-5ee2d0054c3c} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=9, jobs=0): (while reading column key_column): (while reading from part /var/lib/clickhouse/store/cab/cabf9a66-80e2-4148-8335-3c53187f5a8a/all_1_1_0/ in table database_for_dict.table_for_dict (cabf9a66-80e2-4148-8335-3c53187f5a8a) located on disk default of type local, from mark 0 with max_rows_to_read = 1): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder): while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45202) (comment: 01542_dictionary_load_exception_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af80b71 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80746 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000266005a2 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000265fffb4 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:1197: ? @ 0x00000000265fd4e7 9. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:62: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x00000000265e6fbd 10. ./contrib/llvm-project/libcxx/include/future:1123: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x00000000265e7bb3 11. DB::ReadBuffer::next() @ 0x000000000b528aeb 12. ./src/IO/ReadBuffer.h:0: DB::CompressedReadBufferBase::readCompressedDataBlockForAsynchronous(unsigned long&, unsigned long&) @ 0x0000000027760e7f 13. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:110: DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x0000000027764c41 14. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:222: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x0000000027b97730 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 @ 0x0000000027aa00db 16. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:0: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x000000002c7b254b 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7eb79e 18. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:118: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7c9d8a 19. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x000000002c7e0473 20. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x000000002c7dbec3 21. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:0: DB::MergeTreeReadTask::read(DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002c82d05b 22. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:53: DB::MergeTreeInOrderSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&, DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002dea5374 23. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:0: DB::MergeTreeSelectProcessor::read() @ 0x000000002c8242f9 24. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000002de6d77a 25. ./build_docker/./src/Processors/ISource.cpp:0: DB::ISource::work() @ 0x000000002d3290a1 26. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 27. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 28. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 29. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 30. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 31. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 2025.09.09 15:06:58.617268 [ 20884 ] {4834391a-d1a7-4c42-88f9-5ee2d0054c3c} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=9, jobs=0): (while reading column key_column): (while reading from part /var/lib/clickhouse/store/cab/cabf9a66-80e2-4148-8335-3c53187f5a8a/all_1_1_0/ in table database_for_dict.table_for_dict (cabf9a66-80e2-4148-8335-3c53187f5a8a) located on disk default of type local, from mark 0 with max_rows_to_read = 1): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder): while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af80b71 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80746 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000266005a2 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000265fffb4 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:1197: ? @ 0x00000000265fd4e7 9. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:62: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x00000000265e6fbd 10. ./contrib/llvm-project/libcxx/include/future:1123: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x00000000265e7bb3 11. DB::ReadBuffer::next() @ 0x000000000b528aeb 12. ./src/IO/ReadBuffer.h:0: DB::CompressedReadBufferBase::readCompressedDataBlockForAsynchronous(unsigned long&, unsigned long&) @ 0x0000000027760e7f 13. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:110: DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x0000000027764c41 14. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:222: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x0000000027b97730 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 @ 0x0000000027aa00db 16. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:0: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x000000002c7b254b 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7eb79e 18. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:118: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7c9d8a 19. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x000000002c7e0473 20. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x000000002c7dbec3 21. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:0: DB::MergeTreeReadTask::read(DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002c82d05b 22. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:53: DB::MergeTreeInOrderSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&, DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002dea5374 23. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:0: DB::MergeTreeSelectProcessor::read() @ 0x000000002c8242f9 24. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000002de6d77a 25. ./build_docker/./src/Processors/ISource.cpp:0: DB::ISource::work() @ 0x000000002d3290a1 26. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 27. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 28. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 29. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 30. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 31. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 2025.09.09 15:06:58.651094 [ 20338 ] {a41f26eb-ff3e-4d47-81bd-3f516f62390f} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=9, jobs=0): (while reading column key_column): (while reading from part /var/lib/clickhouse/store/cab/cabf9a66-80e2-4148-8335-3c53187f5a8a/all_1_1_0/ in table database_for_dict.table_for_dict (cabf9a66-80e2-4148-8335-3c53187f5a8a) located on disk default of type local, from mark 0 with max_rows_to_read = 1): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder): while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45234) (comment: 01542_dictionary_load_exception_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af80b71 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80746 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000266005a2 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000265fffb4 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:1197: ? @ 0x00000000265fd4e7 9. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:62: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x00000000265e6fbd 10. ./contrib/llvm-project/libcxx/include/future:1123: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x00000000265e7bb3 11. DB::ReadBuffer::next() @ 0x000000000b528aeb 12. ./src/IO/ReadBuffer.h:0: DB::CompressedReadBufferBase::readCompressedDataBlockForAsynchronous(unsigned long&, unsigned long&) @ 0x0000000027760e7f 13. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:110: DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x0000000027764c41 14. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:222: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x0000000027b97730 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 @ 0x0000000027aa00db 16. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:0: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x000000002c7b254b 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7eb79e 18. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:118: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7c9d8a 19. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x000000002c7e0473 20. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x000000002c7dbec3 21. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:0: DB::MergeTreeReadTask::read(DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002c82d05b 22. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:53: DB::MergeTreeInOrderSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&, DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002dea5374 23. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:0: DB::MergeTreeSelectProcessor::read() @ 0x000000002c8242f9 24. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000002de6d77a 25. ./build_docker/./src/Processors/ISource.cpp:0: DB::ISource::work() @ 0x000000002d3290a1 26. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 27. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 28. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 29. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 30. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 31. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 2025.09.09 15:06:58.660384 [ 20338 ] {a41f26eb-ff3e-4d47-81bd-3f516f62390f} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=9, jobs=0): (while reading column key_column): (while reading from part /var/lib/clickhouse/store/cab/cabf9a66-80e2-4148-8335-3c53187f5a8a/all_1_1_0/ in table database_for_dict.table_for_dict (cabf9a66-80e2-4148-8335-3c53187f5a8a) located on disk default of type local, from mark 0 with max_rows_to_read = 1): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder): while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af80b71 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80746 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000266005a2 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000265fffb4 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:1197: ? @ 0x00000000265fd4e7 9. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:62: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x00000000265e6fbd 10. ./contrib/llvm-project/libcxx/include/future:1123: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x00000000265e7bb3 11. DB::ReadBuffer::next() @ 0x000000000b528aeb 12. ./src/IO/ReadBuffer.h:0: DB::CompressedReadBufferBase::readCompressedDataBlockForAsynchronous(unsigned long&, unsigned long&) @ 0x0000000027760e7f 13. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:110: DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x0000000027764c41 14. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:222: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x0000000027b97730 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 @ 0x0000000027aa00db 16. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:0: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x000000002c7b254b 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7eb79e 18. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:118: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7c9d8a 19. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x000000002c7e0473 20. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x000000002c7dbec3 21. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:0: DB::MergeTreeReadTask::read(DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002c82d05b 22. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:53: DB::MergeTreeInOrderSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&, DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002dea5374 23. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:0: DB::MergeTreeSelectProcessor::read() @ 0x000000002c8242f9 24. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000002de6d77a 25. ./build_docker/./src/Processors/ISource.cpp:0: DB::ISource::work() @ 0x000000002d3290a1 26. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 27. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 28. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 29. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 30. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 31. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 2025.09.09 15:06:58.661733 [ 20397 ] {b4d371cb-e784-40ef-b747-1f995fe22c52} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=9, jobs=0): (while reading column key_column): (while reading from part /var/lib/clickhouse/store/cab/cabf9a66-80e2-4148-8335-3c53187f5a8a/all_1_1_0/ in table database_for_dict.table_for_dict (cabf9a66-80e2-4148-8335-3c53187f5a8a) located on disk default of type local, from mark 0 with max_rows_to_read = 1): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder): while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45236) (comment: 01542_dictionary_load_exception_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af80b71 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80746 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000266005a2 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000265fffb4 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:1197: ? @ 0x00000000265fd4e7 9. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:62: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x00000000265e6fbd 10. ./contrib/llvm-project/libcxx/include/future:1123: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x00000000265e7bb3 11. DB::ReadBuffer::next() @ 0x000000000b528aeb 12. ./src/IO/ReadBuffer.h:0: DB::CompressedReadBufferBase::readCompressedDataBlockForAsynchronous(unsigned long&, unsigned long&) @ 0x0000000027760e7f 13. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:110: DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x0000000027764c41 14. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:222: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x0000000027b97730 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 @ 0x0000000027aa00db 16. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:0: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x000000002c7b254b 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7eb79e 18. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:118: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7c9d8a 19. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x000000002c7e0473 20. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x000000002c7dbec3 21. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:0: DB::MergeTreeReadTask::read(DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002c82d05b 22. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:53: DB::MergeTreeInOrderSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&, DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002dea5374 23. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:0: DB::MergeTreeSelectProcessor::read() @ 0x000000002c8242f9 24. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000002de6d77a 25. ./build_docker/./src/Processors/ISource.cpp:0: DB::ISource::work() @ 0x000000002d3290a1 26. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 27. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 28. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 29. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 30. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 31. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 2025.09.09 15:06:58.668067 [ 20397 ] {b4d371cb-e784-40ef-b747-1f995fe22c52} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=9, jobs=0): (while reading column key_column): (while reading from part /var/lib/clickhouse/store/cab/cabf9a66-80e2-4148-8335-3c53187f5a8a/all_1_1_0/ in table database_for_dict.table_for_dict (cabf9a66-80e2-4148-8335-3c53187f5a8a) located on disk default of type local, from mark 0 with max_rows_to_read = 1): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder): while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af80b71 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80746 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000266005a2 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000265fffb4 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:1197: ? @ 0x00000000265fd4e7 9. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:62: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x00000000265e6fbd 10. ./contrib/llvm-project/libcxx/include/future:1123: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x00000000265e7bb3 11. DB::ReadBuffer::next() @ 0x000000000b528aeb 12. ./src/IO/ReadBuffer.h:0: DB::CompressedReadBufferBase::readCompressedDataBlockForAsynchronous(unsigned long&, unsigned long&) @ 0x0000000027760e7f 13. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:110: DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x0000000027764c41 14. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:222: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x0000000027b97730 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 @ 0x0000000027aa00db 16. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:0: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x000000002c7b254b 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7eb79e 18. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:118: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7c9d8a 19. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x000000002c7e0473 20. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x000000002c7dbec3 21. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:0: DB::MergeTreeReadTask::read(DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002c82d05b 22. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:53: DB::MergeTreeInOrderSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&, DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002dea5374 23. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:0: DB::MergeTreeSelectProcessor::read() @ 0x000000002c8242f9 24. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000002de6d77a 25. ./build_docker/./src/Processors/ISource.cpp:0: DB::ISource::work() @ 0x000000002d3290a1 26. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 27. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 28. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 29. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 30. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 31. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 2025.09.09 15:06:58.712080 [ 20881 ] {2b5008c4-aead-4960-bbd3-fdb4f1320ac4} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=9, jobs=0): (while reading column key_column): (while reading from part /var/lib/clickhouse/store/cab/cabf9a66-80e2-4148-8335-3c53187f5a8a/all_1_1_0/ in table database_for_dict.table_for_dict (cabf9a66-80e2-4148-8335-3c53187f5a8a) located on disk default of type local, from mark 0 with max_rows_to_read = 1): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder): while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45240) (comment: 01542_dictionary_load_exception_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af80b71 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80746 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000266005a2 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000265fffb4 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:1197: ? @ 0x00000000265fd4e7 9. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:62: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x00000000265e6fbd 10. ./contrib/llvm-project/libcxx/include/future:1123: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x00000000265e7bb3 11. DB::ReadBuffer::next() @ 0x000000000b528aeb 12. ./src/IO/ReadBuffer.h:0: DB::CompressedReadBufferBase::readCompressedDataBlockForAsynchronous(unsigned long&, unsigned long&) @ 0x0000000027760e7f 13. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:110: DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x0000000027764c41 14. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:222: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x0000000027b97730 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 @ 0x0000000027aa00db 16. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:0: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x000000002c7b254b 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7eb79e 18. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:118: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7c9d8a 19. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x000000002c7e0473 20. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x000000002c7dbec3 21. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:0: DB::MergeTreeReadTask::read(DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002c82d05b 22. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:53: DB::MergeTreeInOrderSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&, DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002dea5374 23. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:0: DB::MergeTreeSelectProcessor::read() @ 0x000000002c8242f9 24. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000002de6d77a 25. ./build_docker/./src/Processors/ISource.cpp:0: DB::ISource::work() @ 0x000000002d3290a1 26. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 27. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 28. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 29. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 30. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 31. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 2025.09.09 15:06:58.717252 [ 20881 ] {2b5008c4-aead-4960-bbd3-fdb4f1320ac4} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=9, jobs=0): (while reading column key_column): (while reading from part /var/lib/clickhouse/store/cab/cabf9a66-80e2-4148-8335-3c53187f5a8a/all_1_1_0/ in table database_for_dict.table_for_dict (cabf9a66-80e2-4148-8335-3c53187f5a8a) located on disk default of type local, from mark 0 with max_rows_to_read = 1): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder): while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af80b71 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80746 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000266005a2 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000265fffb4 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:1197: ? @ 0x00000000265fd4e7 9. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:62: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x00000000265e6fbd 10. ./contrib/llvm-project/libcxx/include/future:1123: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x00000000265e7bb3 11. DB::ReadBuffer::next() @ 0x000000000b528aeb 12. ./src/IO/ReadBuffer.h:0: DB::CompressedReadBufferBase::readCompressedDataBlockForAsynchronous(unsigned long&, unsigned long&) @ 0x0000000027760e7f 13. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:110: DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x0000000027764c41 14. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:222: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x0000000027b97730 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 @ 0x0000000027aa00db 16. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:0: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x000000002c7b254b 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7eb79e 18. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:118: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7c9d8a 19. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x000000002c7e0473 20. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x000000002c7dbec3 21. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:0: DB::MergeTreeReadTask::read(DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002c82d05b 22. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:53: DB::MergeTreeInOrderSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&, DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002dea5374 23. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:0: DB::MergeTreeSelectProcessor::read() @ 0x000000002c8242f9 24. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000002de6d77a 25. ./build_docker/./src/Processors/ISource.cpp:0: DB::ISource::work() @ 0x000000002d3290a1 26. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 27. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 28. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 29. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 30. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 31. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 2025.09.09 15:06:58.879141 [ 20351 ] {335940cf-0352-48d5-a30c-d3020afba237} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=9, jobs=0): (while reading column key_column): (while reading from part /var/lib/clickhouse/store/cab/cabf9a66-80e2-4148-8335-3c53187f5a8a/all_1_1_0/ in table database_for_dict.table_for_dict (cabf9a66-80e2-4148-8335-3c53187f5a8a) located on disk default of type local, from mark 0 with max_rows_to_read = 1): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder): while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45256) (comment: 01542_dictionary_load_exception_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af80b71 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80746 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000266005a2 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000265fffb4 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:1197: ? @ 0x00000000265fd4e7 9. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:62: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x00000000265e6fbd 10. ./contrib/llvm-project/libcxx/include/future:1123: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x00000000265e7bb3 11. DB::ReadBuffer::next() @ 0x000000000b528aeb 12. ./src/IO/ReadBuffer.h:0: DB::CompressedReadBufferBase::readCompressedDataBlockForAsynchronous(unsigned long&, unsigned long&) @ 0x0000000027760e7f 13. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:110: DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x0000000027764c41 14. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:222: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x0000000027b97730 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 @ 0x0000000027aa00db 16. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:0: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x000000002c7b254b 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7eb79e 18. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:118: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7c9d8a 19. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x000000002c7e0473 20. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x000000002c7dbec3 21. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:0: DB::MergeTreeReadTask::read(DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002c82d05b 22. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:53: DB::MergeTreeInOrderSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&, DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002dea5374 23. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:0: DB::MergeTreeSelectProcessor::read() @ 0x000000002c8242f9 24. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000002de6d77a 25. ./build_docker/./src/Processors/ISource.cpp:0: DB::ISource::work() @ 0x000000002d3290a1 26. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 27. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 28. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 29. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 30. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 31. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 2025.09.09 15:06:58.889953 [ 20351 ] {335940cf-0352-48d5-a30c-d3020afba237} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=9, jobs=0): (while reading column key_column): (while reading from part /var/lib/clickhouse/store/cab/cabf9a66-80e2-4148-8335-3c53187f5a8a/all_1_1_0/ in table database_for_dict.table_for_dict (cabf9a66-80e2-4148-8335-3c53187f5a8a) located on disk default of type local, from mark 0 with max_rows_to_read = 1): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder): while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af80b71 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80746 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000266005a2 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000265fffb4 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:1197: ? @ 0x00000000265fd4e7 9. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:62: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x00000000265e6fbd 10. ./contrib/llvm-project/libcxx/include/future:1123: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x00000000265e7bb3 11. DB::ReadBuffer::next() @ 0x000000000b528aeb 12. ./src/IO/ReadBuffer.h:0: DB::CompressedReadBufferBase::readCompressedDataBlockForAsynchronous(unsigned long&, unsigned long&) @ 0x0000000027760e7f 13. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:110: DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x0000000027764c41 14. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:222: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x0000000027b97730 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 @ 0x0000000027aa00db 16. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:0: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x000000002c7b254b 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7eb79e 18. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:118: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7c9d8a 19. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x000000002c7e0473 20. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x000000002c7dbec3 21. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:0: DB::MergeTreeReadTask::read(DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002c82d05b 22. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:53: DB::MergeTreeInOrderSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&, DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002dea5374 23. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:0: DB::MergeTreeSelectProcessor::read() @ 0x000000002c8242f9 24. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000002de6d77a 25. ./build_docker/./src/Processors/ISource.cpp:0: DB::ISource::work() @ 0x000000002d3290a1 26. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 27. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 28. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 29. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 30. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 31. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 2025.09.09 15:06:58.896272 [ 20350 ] {b70e640f-913d-4e2a-a398-1419726c8ed0} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=9, jobs=0): (while reading column key_column): (while reading from part /var/lib/clickhouse/store/cab/cabf9a66-80e2-4148-8335-3c53187f5a8a/all_1_1_0/ in table database_for_dict.table_for_dict (cabf9a66-80e2-4148-8335-3c53187f5a8a) located on disk default of type local, from mark 0 with max_rows_to_read = 1): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder): while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45250) (comment: 01542_dictionary_load_exception_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af80b71 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80746 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000266005a2 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000265fffb4 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:1197: ? @ 0x00000000265fd4e7 9. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:62: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x00000000265e6fbd 10. ./contrib/llvm-project/libcxx/include/future:1123: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x00000000265e7bb3 11. DB::ReadBuffer::next() @ 0x000000000b528aeb 12. ./src/IO/ReadBuffer.h:0: DB::CompressedReadBufferBase::readCompressedDataBlockForAsynchronous(unsigned long&, unsigned long&) @ 0x0000000027760e7f 13. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:110: DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x0000000027764c41 14. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:222: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x0000000027b97730 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 @ 0x0000000027aa00db 16. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:0: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x000000002c7b254b 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7eb79e 18. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:118: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7c9d8a 19. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x000000002c7e0473 20. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x000000002c7dbec3 21. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:0: DB::MergeTreeReadTask::read(DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002c82d05b 22. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:53: DB::MergeTreeInOrderSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&, DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002dea5374 23. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:0: DB::MergeTreeSelectProcessor::read() @ 0x000000002c8242f9 24. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000002de6d77a 25. ./build_docker/./src/Processors/ISource.cpp:0: DB::ISource::work() @ 0x000000002d3290a1 26. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 27. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 28. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 29. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 30. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 31. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 2025.09.09 15:06:58.902516 [ 20350 ] {b70e640f-913d-4e2a-a398-1419726c8ed0} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=9, jobs=0): (while reading column key_column): (while reading from part /var/lib/clickhouse/store/cab/cabf9a66-80e2-4148-8335-3c53187f5a8a/all_1_1_0/ in table database_for_dict.table_for_dict (cabf9a66-80e2-4148-8335-3c53187f5a8a) located on disk default of type local, from mark 0 with max_rows_to_read = 1): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder): while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af80b71 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80746 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000266005a2 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000265fffb4 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:1197: ? @ 0x00000000265fd4e7 9. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:62: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x00000000265e6fbd 10. ./contrib/llvm-project/libcxx/include/future:1123: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x00000000265e7bb3 11. DB::ReadBuffer::next() @ 0x000000000b528aeb 12. ./src/IO/ReadBuffer.h:0: DB::CompressedReadBufferBase::readCompressedDataBlockForAsynchronous(unsigned long&, unsigned long&) @ 0x0000000027760e7f 13. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:110: DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x0000000027764c41 14. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:222: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x0000000027b97730 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 @ 0x0000000027aa00db 16. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:0: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x000000002c7b254b 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7eb79e 18. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:118: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7c9d8a 19. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x000000002c7e0473 20. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x000000002c7dbec3 21. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:0: DB::MergeTreeReadTask::read(DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002c82d05b 22. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:53: DB::MergeTreeInOrderSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&, DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002dea5374 23. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:0: DB::MergeTreeSelectProcessor::read() @ 0x000000002c8242f9 24. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000002de6d77a 25. ./build_docker/./src/Processors/ISource.cpp:0: DB::ISource::work() @ 0x000000002d3290a1 26. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 27. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 28. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 29. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 30. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 31. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 2025.09.09 15:06:58.921194 [ 20882 ] {4ce5c96f-dc12-4439-bf1e-fe235147b66d} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=9, jobs=0): (while reading column key_column): (while reading from part /var/lib/clickhouse/store/cab/cabf9a66-80e2-4148-8335-3c53187f5a8a/all_1_1_0/ in table database_for_dict.table_for_dict (cabf9a66-80e2-4148-8335-3c53187f5a8a) located on disk default of type local, from mark 0 with max_rows_to_read = 1): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder): while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45266) (comment: 01542_dictionary_load_exception_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af80b71 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80746 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000266005a2 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000265fffb4 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:1197: ? @ 0x00000000265fd4e7 9. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:62: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x00000000265e6fbd 10. ./contrib/llvm-project/libcxx/include/future:1123: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x00000000265e7bb3 11. DB::ReadBuffer::next() @ 0x000000000b528aeb 12. ./src/IO/ReadBuffer.h:0: DB::CompressedReadBufferBase::readCompressedDataBlockForAsynchronous(unsigned long&, unsigned long&) @ 0x0000000027760e7f 13. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:110: DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x0000000027764c41 14. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:222: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x0000000027b97730 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 @ 0x0000000027aa00db 16. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:0: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x000000002c7b254b 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7eb79e 18. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:118: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7c9d8a 19. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x000000002c7e0473 20. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x000000002c7dbec3 21. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:0: DB::MergeTreeReadTask::read(DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002c82d05b 22. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:53: DB::MergeTreeInOrderSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&, DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002dea5374 23. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:0: DB::MergeTreeSelectProcessor::read() @ 0x000000002c8242f9 24. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000002de6d77a 25. ./build_docker/./src/Processors/ISource.cpp:0: DB::ISource::work() @ 0x000000002d3290a1 26. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 27. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 28. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 29. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 30. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 31. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 2025.09.09 15:06:58.922805 [ 20882 ] {4ce5c96f-dc12-4439-bf1e-fe235147b66d} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=9, jobs=0): (while reading column key_column): (while reading from part /var/lib/clickhouse/store/cab/cabf9a66-80e2-4148-8335-3c53187f5a8a/all_1_1_0/ in table database_for_dict.table_for_dict (cabf9a66-80e2-4148-8335-3c53187f5a8a) located on disk default of type local, from mark 0 with max_rows_to_read = 1): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder): while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af80b71 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80746 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000266005a2 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000265fffb4 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:1197: ? @ 0x00000000265fd4e7 9. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:62: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x00000000265e6fbd 10. ./contrib/llvm-project/libcxx/include/future:1123: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x00000000265e7bb3 11. DB::ReadBuffer::next() @ 0x000000000b528aeb 12. ./src/IO/ReadBuffer.h:0: DB::CompressedReadBufferBase::readCompressedDataBlockForAsynchronous(unsigned long&, unsigned long&) @ 0x0000000027760e7f 13. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:110: DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x0000000027764c41 14. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:222: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x0000000027b97730 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 @ 0x0000000027aa00db 16. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:0: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x000000002c7b254b 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7eb79e 18. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:118: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7c9d8a 19. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x000000002c7e0473 20. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x000000002c7dbec3 21. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:0: DB::MergeTreeReadTask::read(DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002c82d05b 22. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:53: DB::MergeTreeInOrderSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&, DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002dea5374 23. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:0: DB::MergeTreeSelectProcessor::read() @ 0x000000002c8242f9 24. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000002de6d77a 25. ./build_docker/./src/Processors/ISource.cpp:0: DB::ISource::work() @ 0x000000002d3290a1 26. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 27. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 28. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 29. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 30. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 31. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 2025.09.09 15:06:59.158221 [ 3199 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:06:59.269402 [ 20881 ] {62f123be-5b1a-4642-a578-19e1b048f3c7} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=9, jobs=0): (while reading column key_column): (while reading from part /var/lib/clickhouse/store/cab/cabf9a66-80e2-4148-8335-3c53187f5a8a/all_1_1_0/ in table database_for_dict.table_for_dict (cabf9a66-80e2-4148-8335-3c53187f5a8a) located on disk default of type local, from mark 0 with max_rows_to_read = 1): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder): while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45278) (comment: 01542_dictionary_load_exception_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af80b71 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80746 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000266005a2 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000265fffb4 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:1197: ? @ 0x00000000265fd4e7 9. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:62: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x00000000265e6fbd 10. ./contrib/llvm-project/libcxx/include/future:1123: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x00000000265e7bb3 11. DB::ReadBuffer::next() @ 0x000000000b528aeb 12. ./src/IO/ReadBuffer.h:0: DB::CompressedReadBufferBase::readCompressedDataBlockForAsynchronous(unsigned long&, unsigned long&) @ 0x0000000027760e7f 13. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:110: DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x0000000027764c41 14. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:222: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x0000000027b97730 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 @ 0x0000000027aa00db 16. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:0: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x000000002c7b254b 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7eb79e 18. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:118: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7c9d8a 19. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x000000002c7e0473 20. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x000000002c7dbec3 21. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:0: DB::MergeTreeReadTask::read(DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002c82d05b 22. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:53: DB::MergeTreeInOrderSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&, DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002dea5374 23. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:0: DB::MergeTreeSelectProcessor::read() @ 0x000000002c8242f9 24. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000002de6d77a 25. ./build_docker/./src/Processors/ISource.cpp:0: DB::ISource::work() @ 0x000000002d3290a1 26. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 27. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 28. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 29. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 30. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 31. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 2025.09.09 15:06:59.288176 [ 20881 ] {62f123be-5b1a-4642-a578-19e1b048f3c7} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=9, jobs=0): (while reading column key_column): (while reading from part /var/lib/clickhouse/store/cab/cabf9a66-80e2-4148-8335-3c53187f5a8a/all_1_1_0/ in table database_for_dict.table_for_dict (cabf9a66-80e2-4148-8335-3c53187f5a8a) located on disk default of type local, from mark 0 with max_rows_to_read = 1): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder): while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af80b71 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80746 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000266005a2 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000265fffb4 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:1197: ? @ 0x00000000265fd4e7 9. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:62: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x00000000265e6fbd 10. ./contrib/llvm-project/libcxx/include/future:1123: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x00000000265e7bb3 11. DB::ReadBuffer::next() @ 0x000000000b528aeb 12. ./src/IO/ReadBuffer.h:0: DB::CompressedReadBufferBase::readCompressedDataBlockForAsynchronous(unsigned long&, unsigned long&) @ 0x0000000027760e7f 13. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:110: DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x0000000027764c41 14. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:222: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x0000000027b97730 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 @ 0x0000000027aa00db 16. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:0: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x000000002c7b254b 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7eb79e 18. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:118: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7c9d8a 19. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x000000002c7e0473 20. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x000000002c7dbec3 21. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:0: DB::MergeTreeReadTask::read(DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002c82d05b 22. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:53: DB::MergeTreeInOrderSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&, DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002dea5374 23. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:0: DB::MergeTreeSelectProcessor::read() @ 0x000000002c8242f9 24. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000002de6d77a 25. ./build_docker/./src/Processors/ISource.cpp:0: DB::ISource::work() @ 0x000000002d3290a1 26. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 27. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 28. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 29. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 30. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 31. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 2025.09.09 15:06:59.362536 [ 20884 ] {f0ebef94-9429-4110-8511-f9349bd49ca1} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=9, jobs=0): (while reading column key_column): (while reading from part /var/lib/clickhouse/store/cab/cabf9a66-80e2-4148-8335-3c53187f5a8a/all_1_1_0/ in table database_for_dict.table_for_dict (cabf9a66-80e2-4148-8335-3c53187f5a8a) located on disk default of type local, from mark 0 with max_rows_to_read = 1): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder): while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45300) (comment: 01542_dictionary_load_exception_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af80b71 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80746 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000266005a2 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000265fffb4 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:1197: ? @ 0x00000000265fd4e7 9. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:62: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x00000000265e6fbd 10. ./contrib/llvm-project/libcxx/include/future:1123: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x00000000265e7bb3 11. DB::ReadBuffer::next() @ 0x000000000b528aeb 12. ./src/IO/ReadBuffer.h:0: DB::CompressedReadBufferBase::readCompressedDataBlockForAsynchronous(unsigned long&, unsigned long&) @ 0x0000000027760e7f 13. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:110: DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x0000000027764c41 14. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:222: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x0000000027b97730 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 @ 0x0000000027aa00db 16. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:0: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x000000002c7b254b 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7eb79e 18. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:118: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7c9d8a 19. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x000000002c7e0473 20. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x000000002c7dbec3 21. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:0: DB::MergeTreeReadTask::read(DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002c82d05b 22. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:53: DB::MergeTreeInOrderSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&, DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002dea5374 23. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:0: DB::MergeTreeSelectProcessor::read() @ 0x000000002c8242f9 24. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000002de6d77a 25. ./build_docker/./src/Processors/ISource.cpp:0: DB::ISource::work() @ 0x000000002d3290a1 26. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 27. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 28. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 29. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 30. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 31. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 2025.09.09 15:06:59.370372 [ 20884 ] {f0ebef94-9429-4110-8511-f9349bd49ca1} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=9, jobs=0): (while reading column key_column): (while reading from part /var/lib/clickhouse/store/cab/cabf9a66-80e2-4148-8335-3c53187f5a8a/all_1_1_0/ in table database_for_dict.table_for_dict (cabf9a66-80e2-4148-8335-3c53187f5a8a) located on disk default of type local, from mark 0 with max_rows_to_read = 1): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder): while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af80b71 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80746 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000266005a2 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000265fffb4 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:1197: ? @ 0x00000000265fd4e7 9. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:62: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x00000000265e6fbd 10. ./contrib/llvm-project/libcxx/include/future:1123: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x00000000265e7bb3 11. DB::ReadBuffer::next() @ 0x000000000b528aeb 12. ./src/IO/ReadBuffer.h:0: DB::CompressedReadBufferBase::readCompressedDataBlockForAsynchronous(unsigned long&, unsigned long&) @ 0x0000000027760e7f 13. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:110: DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x0000000027764c41 14. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:222: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x0000000027b97730 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 @ 0x0000000027aa00db 16. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:0: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x000000002c7b254b 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7eb79e 18. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:118: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7c9d8a 19. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x000000002c7e0473 20. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x000000002c7dbec3 21. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:0: DB::MergeTreeReadTask::read(DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002c82d05b 22. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:53: DB::MergeTreeInOrderSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&, DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002dea5374 23. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:0: DB::MergeTreeSelectProcessor::read() @ 0x000000002c8242f9 24. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000002de6d77a 25. ./build_docker/./src/Processors/ISource.cpp:0: DB::ISource::work() @ 0x000000002d3290a1 26. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 27. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 28. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 29. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 30. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 31. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 2025.09.09 15:06:59.394056 [ 3612 ] {f097bfb2-67c5-4653-8d33-67aff0bda686} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=9, jobs=0): (while reading column key_column): (while reading from part /var/lib/clickhouse/store/cab/cabf9a66-80e2-4148-8335-3c53187f5a8a/all_1_1_0/ in table database_for_dict.table_for_dict (cabf9a66-80e2-4148-8335-3c53187f5a8a) located on disk default of type local, from mark 0 with max_rows_to_read = 1): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder): while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45316) (comment: 01542_dictionary_load_exception_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af80b71 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80746 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000266005a2 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000265fffb4 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:1197: ? @ 0x00000000265fd4e7 9. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:62: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x00000000265e6fbd 10. ./contrib/llvm-project/libcxx/include/future:1123: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x00000000265e7bb3 11. DB::ReadBuffer::next() @ 0x000000000b528aeb 12. ./src/IO/ReadBuffer.h:0: DB::CompressedReadBufferBase::readCompressedDataBlockForAsynchronous(unsigned long&, unsigned long&) @ 0x0000000027760e7f 13. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:110: DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x0000000027764c41 14. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:222: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x0000000027b97730 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 @ 0x0000000027aa00db 16. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:0: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x000000002c7b254b 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7eb79e 18. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:118: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7c9d8a 19. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x000000002c7e0473 20. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x000000002c7dbec3 21. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:0: DB::MergeTreeReadTask::read(DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002c82d05b 22. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:53: DB::MergeTreeInOrderSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&, DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002dea5374 23. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:0: DB::MergeTreeSelectProcessor::read() @ 0x000000002c8242f9 24. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000002de6d77a 25. ./build_docker/./src/Processors/ISource.cpp:0: DB::ISource::work() @ 0x000000002d3290a1 26. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 27. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 28. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 29. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 30. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 31. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 2025.09.09 15:06:59.405528 [ 3612 ] {f097bfb2-67c5-4653-8d33-67aff0bda686} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=9, jobs=0): (while reading column key_column): (while reading from part /var/lib/clickhouse/store/cab/cabf9a66-80e2-4148-8335-3c53187f5a8a/all_1_1_0/ in table database_for_dict.table_for_dict (cabf9a66-80e2-4148-8335-3c53187f5a8a) located on disk default of type local, from mark 0 with max_rows_to_read = 1): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder): while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af80b71 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80746 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000266005a2 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000265fffb4 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:1197: ? @ 0x00000000265fd4e7 9. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:62: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x00000000265e6fbd 10. ./contrib/llvm-project/libcxx/include/future:1123: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x00000000265e7bb3 11. DB::ReadBuffer::next() @ 0x000000000b528aeb 12. ./src/IO/ReadBuffer.h:0: DB::CompressedReadBufferBase::readCompressedDataBlockForAsynchronous(unsigned long&, unsigned long&) @ 0x0000000027760e7f 13. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:110: DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x0000000027764c41 14. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:222: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x0000000027b97730 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 @ 0x0000000027aa00db 16. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:0: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x000000002c7b254b 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7eb79e 18. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:118: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7c9d8a 19. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x000000002c7e0473 20. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x000000002c7dbec3 21. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:0: DB::MergeTreeReadTask::read(DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002c82d05b 22. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:53: DB::MergeTreeInOrderSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&, DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002dea5374 23. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:0: DB::MergeTreeSelectProcessor::read() @ 0x000000002c8242f9 24. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000002de6d77a 25. ./build_docker/./src/Processors/ISource.cpp:0: DB::ISource::work() @ 0x000000002d3290a1 26. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 27. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 28. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 29. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 30. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 31. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 2025.09.09 15:06:59.415955 [ 2688 ] {c37260c6-e8a0-416a-8fd8-ba7ce8aace84} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=9, jobs=0): (while reading column key_column): (while reading from part /var/lib/clickhouse/store/cab/cabf9a66-80e2-4148-8335-3c53187f5a8a/all_1_1_0/ in table database_for_dict.table_for_dict (cabf9a66-80e2-4148-8335-3c53187f5a8a) located on disk default of type local, from mark 0 with max_rows_to_read = 1): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder): while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45326) (comment: 01542_dictionary_load_exception_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af80b71 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80746 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000266005a2 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000265fffb4 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:1197: ? @ 0x00000000265fd4e7 9. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:62: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x00000000265e6fbd 10. ./contrib/llvm-project/libcxx/include/future:1123: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x00000000265e7bb3 11. DB::ReadBuffer::next() @ 0x000000000b528aeb 12. ./src/IO/ReadBuffer.h:0: DB::CompressedReadBufferBase::readCompressedDataBlockForAsynchronous(unsigned long&, unsigned long&) @ 0x0000000027760e7f 13. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:110: DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x0000000027764c41 14. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:222: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x0000000027b97730 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 @ 0x0000000027aa00db 16. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:0: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x000000002c7b254b 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7eb79e 18. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:118: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7c9d8a 19. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x000000002c7e0473 20. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x000000002c7dbec3 21. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:0: DB::MergeTreeReadTask::read(DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002c82d05b 22. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:53: DB::MergeTreeInOrderSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&, DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002dea5374 23. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:0: DB::MergeTreeSelectProcessor::read() @ 0x000000002c8242f9 24. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000002de6d77a 25. ./build_docker/./src/Processors/ISource.cpp:0: DB::ISource::work() @ 0x000000002d3290a1 26. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 27. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 28. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 29. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 30. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 31. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 2025.09.09 15:06:59.418084 [ 2688 ] {c37260c6-e8a0-416a-8fd8-ba7ce8aace84} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=9, jobs=0): (while reading column key_column): (while reading from part /var/lib/clickhouse/store/cab/cabf9a66-80e2-4148-8335-3c53187f5a8a/all_1_1_0/ in table database_for_dict.table_for_dict (cabf9a66-80e2-4148-8335-3c53187f5a8a) located on disk default of type local, from mark 0 with max_rows_to_read = 1): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder): while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af80b71 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80746 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000266005a2 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000265fffb4 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:1197: ? @ 0x00000000265fd4e7 9. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:62: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x00000000265e6fbd 10. ./contrib/llvm-project/libcxx/include/future:1123: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x00000000265e7bb3 11. DB::ReadBuffer::next() @ 0x000000000b528aeb 12. ./src/IO/ReadBuffer.h:0: DB::CompressedReadBufferBase::readCompressedDataBlockForAsynchronous(unsigned long&, unsigned long&) @ 0x0000000027760e7f 13. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:110: DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x0000000027764c41 14. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:222: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x0000000027b97730 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 @ 0x0000000027aa00db 16. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:0: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x000000002c7b254b 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7eb79e 18. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:118: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7c9d8a 19. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x000000002c7e0473 20. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x000000002c7dbec3 21. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:0: DB::MergeTreeReadTask::read(DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002c82d05b 22. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:53: DB::MergeTreeInOrderSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&, DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002dea5374 23. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:0: DB::MergeTreeSelectProcessor::read() @ 0x000000002c8242f9 24. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000002de6d77a 25. ./build_docker/./src/Processors/ISource.cpp:0: DB::ISource::work() @ 0x000000002d3290a1 26. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 27. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 28. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 29. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 30. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 31. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 2025.09.09 15:06:59.441199 [ 20882 ] {5b01e372-6843-4ac3-b564-e55c5bc863b0} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=9, jobs=0): (while reading column key_column): (while reading from part /var/lib/clickhouse/store/cab/cabf9a66-80e2-4148-8335-3c53187f5a8a/all_1_1_0/ in table database_for_dict.table_for_dict (cabf9a66-80e2-4148-8335-3c53187f5a8a) located on disk default of type local, from mark 0 with max_rows_to_read = 1): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder): while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45290) (comment: 01542_dictionary_load_exception_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af80b71 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80746 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000266005a2 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000265fffb4 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:1197: ? @ 0x00000000265fd4e7 9. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:62: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x00000000265e6fbd 10. ./contrib/llvm-project/libcxx/include/future:1123: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x00000000265e7bb3 11. DB::ReadBuffer::next() @ 0x000000000b528aeb 12. ./src/IO/ReadBuffer.h:0: DB::CompressedReadBufferBase::readCompressedDataBlockForAsynchronous(unsigned long&, unsigned long&) @ 0x0000000027760e7f 13. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:110: DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x0000000027764c41 14. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:222: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x0000000027b97730 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 @ 0x0000000027aa00db 16. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:0: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x000000002c7b254b 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7eb79e 18. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:118: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7c9d8a 19. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x000000002c7e0473 20. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x000000002c7dbec3 21. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:0: DB::MergeTreeReadTask::read(DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002c82d05b 22. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:53: DB::MergeTreeInOrderSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&, DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002dea5374 23. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:0: DB::MergeTreeSelectProcessor::read() @ 0x000000002c8242f9 24. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000002de6d77a 25. ./build_docker/./src/Processors/ISource.cpp:0: DB::ISource::work() @ 0x000000002d3290a1 26. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 27. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 28. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 29. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 30. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 31. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 2025.09.09 15:06:59.446429 [ 20882 ] {5b01e372-6843-4ac3-b564-e55c5bc863b0} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=9, jobs=0): (while reading column key_column): (while reading from part /var/lib/clickhouse/store/cab/cabf9a66-80e2-4148-8335-3c53187f5a8a/all_1_1_0/ in table database_for_dict.table_for_dict (cabf9a66-80e2-4148-8335-3c53187f5a8a) located on disk default of type local, from mark 0 with max_rows_to_read = 1): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder): while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af80b71 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80746 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000266005a2 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000265fffb4 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:1197: ? @ 0x00000000265fd4e7 9. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:62: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x00000000265e6fbd 10. ./contrib/llvm-project/libcxx/include/future:1123: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x00000000265e7bb3 11. DB::ReadBuffer::next() @ 0x000000000b528aeb 12. ./src/IO/ReadBuffer.h:0: DB::CompressedReadBufferBase::readCompressedDataBlockForAsynchronous(unsigned long&, unsigned long&) @ 0x0000000027760e7f 13. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:110: DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x0000000027764c41 14. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:222: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x0000000027b97730 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 @ 0x0000000027aa00db 16. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:0: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x000000002c7b254b 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7eb79e 18. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:118: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7c9d8a 19. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x000000002c7e0473 20. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x000000002c7dbec3 21. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:0: DB::MergeTreeReadTask::read(DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002c82d05b 22. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:53: DB::MergeTreeInOrderSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&, DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002dea5374 23. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:0: DB::MergeTreeSelectProcessor::read() @ 0x000000002c8242f9 24. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000002de6d77a 25. ./build_docker/./src/Processors/ISource.cpp:0: DB::ISource::work() @ 0x000000002d3290a1 26. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 27. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 28. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 29. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 30. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 31. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 2025.09.09 15:06:59.452901 [ 20338 ] {08da9d08-0992-43c3-986d-2c7264e59b73} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=9, jobs=0): (while reading column key_column): (while reading from part /var/lib/clickhouse/store/cab/cabf9a66-80e2-4148-8335-3c53187f5a8a/all_1_1_0/ in table database_for_dict.table_for_dict (cabf9a66-80e2-4148-8335-3c53187f5a8a) located on disk default of type local, from mark 0 with max_rows_to_read = 1): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder): while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45328) (comment: 01542_dictionary_load_exception_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af80b71 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80746 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000266005a2 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000265fffb4 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:1197: ? @ 0x00000000265fd4e7 9. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:62: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x00000000265e6fbd 10. ./contrib/llvm-project/libcxx/include/future:1123: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x00000000265e7bb3 11. DB::ReadBuffer::next() @ 0x000000000b528aeb 12. ./src/IO/ReadBuffer.h:0: DB::CompressedReadBufferBase::readCompressedDataBlockForAsynchronous(unsigned long&, unsigned long&) @ 0x0000000027760e7f 13. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:110: DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x0000000027764c41 14. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:222: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x0000000027b97730 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 @ 0x0000000027aa00db 16. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:0: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x000000002c7b254b 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7eb79e 18. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:118: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7c9d8a 19. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x000000002c7e0473 20. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x000000002c7dbec3 21. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:0: DB::MergeTreeReadTask::read(DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002c82d05b 22. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:53: DB::MergeTreeInOrderSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&, DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002dea5374 23. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:0: DB::MergeTreeSelectProcessor::read() @ 0x000000002c8242f9 24. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000002de6d77a 25. ./build_docker/./src/Processors/ISource.cpp:0: DB::ISource::work() @ 0x000000002d3290a1 26. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 27. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 28. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 29. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 30. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 31. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 2025.09.09 15:06:59.454809 [ 20338 ] {08da9d08-0992-43c3-986d-2c7264e59b73} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=9, jobs=0): (while reading column key_column): (while reading from part /var/lib/clickhouse/store/cab/cabf9a66-80e2-4148-8335-3c53187f5a8a/all_1_1_0/ in table database_for_dict.table_for_dict (cabf9a66-80e2-4148-8335-3c53187f5a8a) located on disk default of type local, from mark 0 with max_rows_to_read = 1): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder): while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af80b71 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80746 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000266005a2 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000265fffb4 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:1197: ? @ 0x00000000265fd4e7 9. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:62: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x00000000265e6fbd 10. ./contrib/llvm-project/libcxx/include/future:1123: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x00000000265e7bb3 11. DB::ReadBuffer::next() @ 0x000000000b528aeb 12. ./src/IO/ReadBuffer.h:0: DB::CompressedReadBufferBase::readCompressedDataBlockForAsynchronous(unsigned long&, unsigned long&) @ 0x0000000027760e7f 13. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:110: DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x0000000027764c41 14. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:222: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x0000000027b97730 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 @ 0x0000000027aa00db 16. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:0: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x000000002c7b254b 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7eb79e 18. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:118: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7c9d8a 19. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x000000002c7e0473 20. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x000000002c7dbec3 21. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:0: DB::MergeTreeReadTask::read(DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002c82d05b 22. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:53: DB::MergeTreeInOrderSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&, DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002dea5374 23. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:0: DB::MergeTreeSelectProcessor::read() @ 0x000000002c8242f9 24. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000002de6d77a 25. ./build_docker/./src/Processors/ISource.cpp:0: DB::ISource::work() @ 0x000000002d3290a1 26. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 27. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 28. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 29. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 30. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 31. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 2025.09.09 15:06:59.513077 [ 3210 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:06:59.514263 [ 3208 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:06:59.514590 [ 19252 ] {f0d2daf4-c09f-4367-a8dc-7498cdce64ca} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=9, jobs=0): (while reading column key_column): (while reading from part /var/lib/clickhouse/store/cab/cabf9a66-80e2-4148-8335-3c53187f5a8a/all_1_1_0/ in table database_for_dict.table_for_dict (cabf9a66-80e2-4148-8335-3c53187f5a8a) located on disk default of type local, from mark 0 with max_rows_to_read = 1): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder): while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45334) (comment: 01542_dictionary_load_exception_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af80b71 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80746 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000266005a2 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000265fffb4 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:1197: ? @ 0x00000000265fd4e7 9. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:62: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x00000000265e6fbd 10. ./contrib/llvm-project/libcxx/include/future:1123: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x00000000265e7bb3 11. DB::ReadBuffer::next() @ 0x000000000b528aeb 12. ./src/IO/ReadBuffer.h:0: DB::CompressedReadBufferBase::readCompressedDataBlockForAsynchronous(unsigned long&, unsigned long&) @ 0x0000000027760e7f 13. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:110: DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x0000000027764c41 14. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:222: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x0000000027b97730 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 @ 0x0000000027aa00db 16. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:0: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x000000002c7b254b 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7eb79e 18. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:118: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7c9d8a 19. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x000000002c7e0473 20. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x000000002c7dbec3 21. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:0: DB::MergeTreeReadTask::read(DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002c82d05b 22. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:53: DB::MergeTreeInOrderSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&, DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002dea5374 23. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:0: DB::MergeTreeSelectProcessor::read() @ 0x000000002c8242f9 24. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000002de6d77a 25. ./build_docker/./src/Processors/ISource.cpp:0: DB::ISource::work() @ 0x000000002d3290a1 26. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 27. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 28. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 29. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 30. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 31. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 2025.09.09 15:06:59.522374 [ 19252 ] {f0d2daf4-c09f-4367-a8dc-7498cdce64ca} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=9, jobs=0): (while reading column key_column): (while reading from part /var/lib/clickhouse/store/cab/cabf9a66-80e2-4148-8335-3c53187f5a8a/all_1_1_0/ in table database_for_dict.table_for_dict (cabf9a66-80e2-4148-8335-3c53187f5a8a) located on disk default of type local, from mark 0 with max_rows_to_read = 1): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder): while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af80b71 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80746 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000266005a2 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000265fffb4 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:1197: ? @ 0x00000000265fd4e7 9. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:62: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x00000000265e6fbd 10. ./contrib/llvm-project/libcxx/include/future:1123: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x00000000265e7bb3 11. DB::ReadBuffer::next() @ 0x000000000b528aeb 12. ./src/IO/ReadBuffer.h:0: DB::CompressedReadBufferBase::readCompressedDataBlockForAsynchronous(unsigned long&, unsigned long&) @ 0x0000000027760e7f 13. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:110: DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x0000000027764c41 14. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:222: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x0000000027b97730 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 @ 0x0000000027aa00db 16. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:0: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x000000002c7b254b 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7eb79e 18. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:118: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7c9d8a 19. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x000000002c7e0473 20. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x000000002c7dbec3 21. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:0: DB::MergeTreeReadTask::read(DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002c82d05b 22. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:53: DB::MergeTreeInOrderSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&, DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002dea5374 23. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:0: DB::MergeTreeSelectProcessor::read() @ 0x000000002c8242f9 24. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000002de6d77a 25. ./build_docker/./src/Processors/ISource.cpp:0: DB::ISource::work() @ 0x000000002d3290a1 26. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 27. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 28. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 29. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 30. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 31. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 2025.09.09 15:06:59.579869 [ 20849 ] {8adcce12-2cc1-47d3-bd75-e4a5ab1bd09d} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=9, jobs=0): (while reading column key_column): (while reading from part /var/lib/clickhouse/store/cab/cabf9a66-80e2-4148-8335-3c53187f5a8a/all_1_1_0/ in table database_for_dict.table_for_dict (cabf9a66-80e2-4148-8335-3c53187f5a8a) located on disk default of type local, from mark 0 with max_rows_to_read = 1): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder): while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45350) (comment: 01542_dictionary_load_exception_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af80b71 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80746 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000266005a2 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000265fffb4 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:1197: ? @ 0x00000000265fd4e7 9. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:62: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x00000000265e6fbd 10. ./contrib/llvm-project/libcxx/include/future:1123: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x00000000265e7bb3 11. DB::ReadBuffer::next() @ 0x000000000b528aeb 12. ./src/IO/ReadBuffer.h:0: DB::CompressedReadBufferBase::readCompressedDataBlockForAsynchronous(unsigned long&, unsigned long&) @ 0x0000000027760e7f 13. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:110: DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x0000000027764c41 14. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:222: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x0000000027b97730 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 @ 0x0000000027aa00db 16. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:0: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x000000002c7b254b 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7eb79e 18. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:118: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7c9d8a 19. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x000000002c7e0473 20. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x000000002c7dbec3 21. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:0: DB::MergeTreeReadTask::read(DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002c82d05b 22. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:53: DB::MergeTreeInOrderSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&, DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002dea5374 23. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:0: DB::MergeTreeSelectProcessor::read() @ 0x000000002c8242f9 24. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000002de6d77a 25. ./build_docker/./src/Processors/ISource.cpp:0: DB::ISource::work() @ 0x000000002d3290a1 26. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 27. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 28. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 29. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 30. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 31. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 2025.09.09 15:06:59.595932 [ 20849 ] {8adcce12-2cc1-47d3-bd75-e4a5ab1bd09d} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=9, jobs=0): (while reading column key_column): (while reading from part /var/lib/clickhouse/store/cab/cabf9a66-80e2-4148-8335-3c53187f5a8a/all_1_1_0/ in table database_for_dict.table_for_dict (cabf9a66-80e2-4148-8335-3c53187f5a8a) located on disk default of type local, from mark 0 with max_rows_to_read = 1): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder): while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af80b71 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80746 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000266005a2 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000265fffb4 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:1197: ? @ 0x00000000265fd4e7 9. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:62: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x00000000265e6fbd 10. ./contrib/llvm-project/libcxx/include/future:1123: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x00000000265e7bb3 11. DB::ReadBuffer::next() @ 0x000000000b528aeb 12. ./src/IO/ReadBuffer.h:0: DB::CompressedReadBufferBase::readCompressedDataBlockForAsynchronous(unsigned long&, unsigned long&) @ 0x0000000027760e7f 13. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:110: DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x0000000027764c41 14. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:222: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x0000000027b97730 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 @ 0x0000000027aa00db 16. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:0: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x000000002c7b254b 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7eb79e 18. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:118: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7c9d8a 19. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x000000002c7e0473 20. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x000000002c7dbec3 21. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:0: DB::MergeTreeReadTask::read(DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002c82d05b 22. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:53: DB::MergeTreeInOrderSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&, DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002dea5374 23. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:0: DB::MergeTreeSelectProcessor::read() @ 0x000000002c8242f9 24. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000002de6d77a 25. ./build_docker/./src/Processors/ISource.cpp:0: DB::ISource::work() @ 0x000000002d3290a1 26. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 27. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 28. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 29. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 30. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 31. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 2025.09.09 15:06:59.614447 [ 3212 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:06:59.732335 [ 20397 ] {0ebbad56-b9a5-47a0-8923-23bb2689d10c} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=9, jobs=0): (while reading column key_column): (while reading from part /var/lib/clickhouse/store/cab/cabf9a66-80e2-4148-8335-3c53187f5a8a/all_1_1_0/ in table database_for_dict.table_for_dict (cabf9a66-80e2-4148-8335-3c53187f5a8a) located on disk default of type local, from mark 0 with max_rows_to_read = 1): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder): while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45360) (comment: 01542_dictionary_load_exception_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af80b71 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80746 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000266005a2 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000265fffb4 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:1197: ? @ 0x00000000265fd4e7 9. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:62: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x00000000265e6fbd 10. ./contrib/llvm-project/libcxx/include/future:1123: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x00000000265e7bb3 11. DB::ReadBuffer::next() @ 0x000000000b528aeb 12. ./src/IO/ReadBuffer.h:0: DB::CompressedReadBufferBase::readCompressedDataBlockForAsynchronous(unsigned long&, unsigned long&) @ 0x0000000027760e7f 13. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:110: DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x0000000027764c41 14. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:222: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x0000000027b97730 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 @ 0x0000000027aa00db 16. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:0: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x000000002c7b254b 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7eb79e 18. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:118: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7c9d8a 19. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x000000002c7e0473 20. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x000000002c7dbec3 21. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:0: DB::MergeTreeReadTask::read(DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002c82d05b 22. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:53: DB::MergeTreeInOrderSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&, DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002dea5374 23. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:0: DB::MergeTreeSelectProcessor::read() @ 0x000000002c8242f9 24. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000002de6d77a 25. ./build_docker/./src/Processors/ISource.cpp:0: DB::ISource::work() @ 0x000000002d3290a1 26. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 27. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 28. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 29. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 30. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 31. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 2025.09.09 15:06:59.734110 [ 20397 ] {0ebbad56-b9a5-47a0-8923-23bb2689d10c} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=9, jobs=0): (while reading column key_column): (while reading from part /var/lib/clickhouse/store/cab/cabf9a66-80e2-4148-8335-3c53187f5a8a/all_1_1_0/ in table database_for_dict.table_for_dict (cabf9a66-80e2-4148-8335-3c53187f5a8a) located on disk default of type local, from mark 0 with max_rows_to_read = 1): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder): while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af80b71 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80746 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000266005a2 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000265fffb4 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:1197: ? @ 0x00000000265fd4e7 9. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:62: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x00000000265e6fbd 10. ./contrib/llvm-project/libcxx/include/future:1123: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x00000000265e7bb3 11. DB::ReadBuffer::next() @ 0x000000000b528aeb 12. ./src/IO/ReadBuffer.h:0: DB::CompressedReadBufferBase::readCompressedDataBlockForAsynchronous(unsigned long&, unsigned long&) @ 0x0000000027760e7f 13. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:110: DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x0000000027764c41 14. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:222: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x0000000027b97730 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 @ 0x0000000027aa00db 16. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:0: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x000000002c7b254b 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7eb79e 18. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:118: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7c9d8a 19. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x000000002c7e0473 20. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x000000002c7dbec3 21. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:0: DB::MergeTreeReadTask::read(DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002c82d05b 22. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:53: DB::MergeTreeInOrderSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&, DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002dea5374 23. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:0: DB::MergeTreeSelectProcessor::read() @ 0x000000002c8242f9 24. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000002de6d77a 25. ./build_docker/./src/Processors/ISource.cpp:0: DB::ISource::work() @ 0x000000002d3290a1 26. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 27. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 28. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 29. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 30. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 31. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 2025.09.09 15:06:59.888454 [ 20881 ] {1ca62118-3ea9-479f-960b-1816e17000ee} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=9, jobs=0): (while reading column key_column): (while reading from part /var/lib/clickhouse/store/cab/cabf9a66-80e2-4148-8335-3c53187f5a8a/all_1_1_0/ in table database_for_dict.table_for_dict (cabf9a66-80e2-4148-8335-3c53187f5a8a) located on disk default of type local, from mark 0 with max_rows_to_read = 1): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder): while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45362) (comment: 01542_dictionary_load_exception_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af80b71 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80746 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000266005a2 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000265fffb4 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:1197: ? @ 0x00000000265fd4e7 9. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:62: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x00000000265e6fbd 10. ./contrib/llvm-project/libcxx/include/future:1123: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x00000000265e7bb3 11. DB::ReadBuffer::next() @ 0x000000000b528aeb 12. ./src/IO/ReadBuffer.h:0: DB::CompressedReadBufferBase::readCompressedDataBlockForAsynchronous(unsigned long&, unsigned long&) @ 0x0000000027760e7f 13. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:110: DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x0000000027764c41 14. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:222: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x0000000027b97730 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 @ 0x0000000027aa00db 16. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:0: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x000000002c7b254b 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7eb79e 18. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:118: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7c9d8a 19. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x000000002c7e0473 20. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x000000002c7dbec3 21. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:0: DB::MergeTreeReadTask::read(DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002c82d05b 22. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:53: DB::MergeTreeInOrderSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&, DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002dea5374 23. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:0: DB::MergeTreeSelectProcessor::read() @ 0x000000002c8242f9 24. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000002de6d77a 25. ./build_docker/./src/Processors/ISource.cpp:0: DB::ISource::work() @ 0x000000002d3290a1 26. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 27. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 28. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 29. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 30. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 31. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 2025.09.09 15:06:59.894388 [ 20881 ] {1ca62118-3ea9-479f-960b-1816e17000ee} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=9, jobs=0): (while reading column key_column): (while reading from part /var/lib/clickhouse/store/cab/cabf9a66-80e2-4148-8335-3c53187f5a8a/all_1_1_0/ in table database_for_dict.table_for_dict (cabf9a66-80e2-4148-8335-3c53187f5a8a) located on disk default of type local, from mark 0 with max_rows_to_read = 1): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder): while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af80b71 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80746 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000266005a2 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000265fffb4 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:1197: ? @ 0x00000000265fd4e7 9. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:62: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x00000000265e6fbd 10. ./contrib/llvm-project/libcxx/include/future:1123: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x00000000265e7bb3 11. DB::ReadBuffer::next() @ 0x000000000b528aeb 12. ./src/IO/ReadBuffer.h:0: DB::CompressedReadBufferBase::readCompressedDataBlockForAsynchronous(unsigned long&, unsigned long&) @ 0x0000000027760e7f 13. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:110: DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x0000000027764c41 14. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:222: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x0000000027b97730 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 @ 0x0000000027aa00db 16. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:0: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x000000002c7b254b 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7eb79e 18. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:118: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7c9d8a 19. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x000000002c7e0473 20. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x000000002c7dbec3 21. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:0: DB::MergeTreeReadTask::read(DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002c82d05b 22. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:53: DB::MergeTreeInOrderSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&, DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002dea5374 23. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:0: DB::MergeTreeSelectProcessor::read() @ 0x000000002c8242f9 24. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000002de6d77a 25. ./build_docker/./src/Processors/ISource.cpp:0: DB::ISource::work() @ 0x000000002d3290a1 26. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 27. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 28. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 29. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 30. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 31. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 2025.09.09 15:06:59.905357 [ 20882 ] {cf840920-58f9-4589-bb6e-bad47e1c424f} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=9, jobs=0): (while reading column key_column): (while reading from part /var/lib/clickhouse/store/cab/cabf9a66-80e2-4148-8335-3c53187f5a8a/all_1_1_0/ in table database_for_dict.table_for_dict (cabf9a66-80e2-4148-8335-3c53187f5a8a) located on disk default of type local, from mark 0 with max_rows_to_read = 1): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder): while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45364) (comment: 01542_dictionary_load_exception_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af80b71 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80746 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000266005a2 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000265fffb4 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:1197: ? @ 0x00000000265fd4e7 9. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:62: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x00000000265e6fbd 10. ./contrib/llvm-project/libcxx/include/future:1123: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x00000000265e7bb3 11. DB::ReadBuffer::next() @ 0x000000000b528aeb 12. ./src/IO/ReadBuffer.h:0: DB::CompressedReadBufferBase::readCompressedDataBlockForAsynchronous(unsigned long&, unsigned long&) @ 0x0000000027760e7f 13. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:110: DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x0000000027764c41 14. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:222: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x0000000027b97730 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 @ 0x0000000027aa00db 16. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:0: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x000000002c7b254b 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7eb79e 18. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:118: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7c9d8a 19. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x000000002c7e0473 20. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x000000002c7dbec3 21. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:0: DB::MergeTreeReadTask::read(DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002c82d05b 22. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:53: DB::MergeTreeInOrderSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&, DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002dea5374 23. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:0: DB::MergeTreeSelectProcessor::read() @ 0x000000002c8242f9 24. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000002de6d77a 25. ./build_docker/./src/Processors/ISource.cpp:0: DB::ISource::work() @ 0x000000002d3290a1 26. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 27. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 28. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 29. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 30. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 31. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 2025.09.09 15:06:59.909001 [ 20882 ] {cf840920-58f9-4589-bb6e-bad47e1c424f} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=9, jobs=0): (while reading column key_column): (while reading from part /var/lib/clickhouse/store/cab/cabf9a66-80e2-4148-8335-3c53187f5a8a/all_1_1_0/ in table database_for_dict.table_for_dict (cabf9a66-80e2-4148-8335-3c53187f5a8a) located on disk default of type local, from mark 0 with max_rows_to_read = 1): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder): while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af80b71 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80746 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000266005a2 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000265fffb4 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:1197: ? @ 0x00000000265fd4e7 9. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:62: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x00000000265e6fbd 10. ./contrib/llvm-project/libcxx/include/future:1123: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x00000000265e7bb3 11. DB::ReadBuffer::next() @ 0x000000000b528aeb 12. ./src/IO/ReadBuffer.h:0: DB::CompressedReadBufferBase::readCompressedDataBlockForAsynchronous(unsigned long&, unsigned long&) @ 0x0000000027760e7f 13. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:110: DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x0000000027764c41 14. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:222: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x0000000027b97730 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 @ 0x0000000027aa00db 16. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:0: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x000000002c7b254b 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7eb79e 18. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:118: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7c9d8a 19. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x000000002c7e0473 20. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x000000002c7dbec3 21. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:0: DB::MergeTreeReadTask::read(DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002c82d05b 22. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:53: DB::MergeTreeInOrderSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&, DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002dea5374 23. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:0: DB::MergeTreeSelectProcessor::read() @ 0x000000002c8242f9 24. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000002de6d77a 25. ./build_docker/./src/Processors/ISource.cpp:0: DB::ISource::work() @ 0x000000002d3290a1 26. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 27. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 28. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 29. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 30. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 31. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 2025.09.09 15:06:59.979119 [ 20884 ] {df970bfc-3d35-4d7d-b2fa-793e819321cc} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=9, jobs=0): (while reading column key_column): (while reading from part /var/lib/clickhouse/store/cab/cabf9a66-80e2-4148-8335-3c53187f5a8a/all_1_1_0/ in table database_for_dict.table_for_dict (cabf9a66-80e2-4148-8335-3c53187f5a8a) located on disk default of type local, from mark 0 with max_rows_to_read = 1): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder): while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45378) (comment: 01542_dictionary_load_exception_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af80b71 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80746 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000266005a2 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000265fffb4 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:1197: ? @ 0x00000000265fd4e7 9. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:62: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x00000000265e6fbd 10. ./contrib/llvm-project/libcxx/include/future:1123: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x00000000265e7bb3 11. DB::ReadBuffer::next() @ 0x000000000b528aeb 12. ./src/IO/ReadBuffer.h:0: DB::CompressedReadBufferBase::readCompressedDataBlockForAsynchronous(unsigned long&, unsigned long&) @ 0x0000000027760e7f 13. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:110: DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x0000000027764c41 14. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:222: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x0000000027b97730 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 @ 0x0000000027aa00db 16. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:0: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x000000002c7b254b 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7eb79e 18. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:118: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7c9d8a 19. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x000000002c7e0473 20. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x000000002c7dbec3 21. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:0: DB::MergeTreeReadTask::read(DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002c82d05b 22. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:53: DB::MergeTreeInOrderSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&, DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002dea5374 23. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:0: DB::MergeTreeSelectProcessor::read() @ 0x000000002c8242f9 24. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000002de6d77a 25. ./build_docker/./src/Processors/ISource.cpp:0: DB::ISource::work() @ 0x000000002d3290a1 26. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 27. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 28. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 29. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 30. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 31. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 2025.09.09 15:06:59.980899 [ 20884 ] {df970bfc-3d35-4d7d-b2fa-793e819321cc} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=9, jobs=0): (while reading column key_column): (while reading from part /var/lib/clickhouse/store/cab/cabf9a66-80e2-4148-8335-3c53187f5a8a/all_1_1_0/ in table database_for_dict.table_for_dict (cabf9a66-80e2-4148-8335-3c53187f5a8a) located on disk default of type local, from mark 0 with max_rows_to_read = 1): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder): while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af80b71 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80746 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000266005a2 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000265fffb4 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:1197: ? @ 0x00000000265fd4e7 9. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:62: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x00000000265e6fbd 10. ./contrib/llvm-project/libcxx/include/future:1123: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x00000000265e7bb3 11. DB::ReadBuffer::next() @ 0x000000000b528aeb 12. ./src/IO/ReadBuffer.h:0: DB::CompressedReadBufferBase::readCompressedDataBlockForAsynchronous(unsigned long&, unsigned long&) @ 0x0000000027760e7f 13. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:110: DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x0000000027764c41 14. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:222: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x0000000027b97730 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 @ 0x0000000027aa00db 16. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:0: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x000000002c7b254b 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7eb79e 18. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:118: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7c9d8a 19. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x000000002c7e0473 20. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x000000002c7dbec3 21. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:0: DB::MergeTreeReadTask::read(DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002c82d05b 22. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:53: DB::MergeTreeInOrderSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&, DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002dea5374 23. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:0: DB::MergeTreeSelectProcessor::read() @ 0x000000002c8242f9 24. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000002de6d77a 25. ./build_docker/./src/Processors/ISource.cpp:0: DB::ISource::work() @ 0x000000002d3290a1 26. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 27. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 28. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 29. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 30. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 31. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 2025.09.09 15:07:00.099091 [ 19252 ] {aded0afb-8ecf-4b10-b27e-9bf110cecad0} executeQuery: Code: 636. DB::Exception: The table structure cannot be extracted from a Parquet format file. Error: Code: 50. DB::Exception: Unsupported Parquet type 'null' of an input column 'error_message'. If it happens during schema inference and you want to skip columns with unsupported types, you can enable setting input_format_parquet_skip_columns_with_unsupported_types_in_schema_inference. (UNKNOWN_TYPE) (version 24.8.14.10505.altinitytest (altinity build)). You can specify the structure manually: (in file/uri /var/lib/clickhouse/user_files/test_02245.parquet). (CANNOT_EXTRACT_TABLE_STRUCTURE) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45388) (comment: 02245_parquet_skip_unknown_type.sh) (in query: desc file(test_02245.parquet)), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&, String&) @ 0x00000000180b4b3a 4. ./build_docker/./src/Formats/ReadSchemaUtils.cpp:280: DB::readSchemaFromFormatImpl(std::optional, std::optional const&, DB::IReadBufferIterator&, std::shared_ptr const&) @ 0x000000002d2c2ce6 5. ./build_docker/./src/Formats/ReadSchemaUtils.cpp:0: DB::readSchemaFromFormat(String const&, std::optional const&, DB::IReadBufferIterator&, std::shared_ptr const&) @ 0x000000002d2c4e9b 6. ./build_docker/./src/Storages/StorageFile.cpp:0: DB::StorageFile::getTableStructureAndFormatFromFileImpl(std::optional, std::vector> const&, String const&, std::optional const&, std::shared_ptr const&, std::optional const&) @ 0x000000002b787971 7. ./build_docker/./src/Storages/StorageFile.cpp:972: DB::StorageFile::getTableStructureFromFile(String const&, std::vector> const&, String const&, std::optional const&, std::shared_ptr const&, std::optional const&) @ 0x000000002b788c72 8. ./build_docker/./src/TableFunctions/TableFunctionFile.cpp:114: DB::TableFunctionFile::getActualTableStructure(std::shared_ptr, bool) const @ 0x0000000025fe4604 9. ./contrib/boost/boost/multi_index_container.hpp:640: DB::InterpreterDescribeQuery::fillColumnsFromTableFunction(DB::ASTTableExpression const&) @ 0x0000000029bed1cc 10. ./build_docker/./src/Interpreters/InterpreterDescribeQuery.cpp:0: DB::InterpreterDescribeQuery::execute() @ 0x0000000029beb3c3 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b382fc 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 14. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 19. asan_thread_start(void*) @ 0x000000000aa43059 20. ? @ 0x00007f35aab92ac3 21. ? @ 0x00007f35aac24850 2025.09.09 15:07:00.106553 [ 19252 ] {aded0afb-8ecf-4b10-b27e-9bf110cecad0} TCPHandler: Code: 636. DB::Exception: The table structure cannot be extracted from a Parquet format file. Error: Code: 50. DB::Exception: Unsupported Parquet type 'null' of an input column 'error_message'. If it happens during schema inference and you want to skip columns with unsupported types, you can enable setting input_format_parquet_skip_columns_with_unsupported_types_in_schema_inference. (UNKNOWN_TYPE) (version 24.8.14.10505.altinitytest (altinity build)). You can specify the structure manually: (in file/uri /var/lib/clickhouse/user_files/test_02245.parquet). (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&, String&) @ 0x00000000180b4b3a 4. ./build_docker/./src/Formats/ReadSchemaUtils.cpp:280: DB::readSchemaFromFormatImpl(std::optional, std::optional const&, DB::IReadBufferIterator&, std::shared_ptr const&) @ 0x000000002d2c2ce6 5. ./build_docker/./src/Formats/ReadSchemaUtils.cpp:0: DB::readSchemaFromFormat(String const&, std::optional const&, DB::IReadBufferIterator&, std::shared_ptr const&) @ 0x000000002d2c4e9b 6. ./build_docker/./src/Storages/StorageFile.cpp:0: DB::StorageFile::getTableStructureAndFormatFromFileImpl(std::optional, std::vector> const&, String const&, std::optional const&, std::shared_ptr const&, std::optional const&) @ 0x000000002b787971 7. ./build_docker/./src/Storages/StorageFile.cpp:972: DB::StorageFile::getTableStructureFromFile(String const&, std::vector> const&, String const&, std::optional const&, std::shared_ptr const&, std::optional const&) @ 0x000000002b788c72 8. ./build_docker/./src/TableFunctions/TableFunctionFile.cpp:114: DB::TableFunctionFile::getActualTableStructure(std::shared_ptr, bool) const @ 0x0000000025fe4604 9. ./contrib/boost/boost/multi_index_container.hpp:640: DB::InterpreterDescribeQuery::fillColumnsFromTableFunction(DB::ASTTableExpression const&) @ 0x0000000029bed1cc 10. ./build_docker/./src/Interpreters/InterpreterDescribeQuery.cpp:0: DB::InterpreterDescribeQuery::execute() @ 0x0000000029beb3c3 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b382fc 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 14. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 19. asan_thread_start(void*) @ 0x000000000aa43059 20. ? @ 0x00007f35aab92ac3 21. ? @ 0x00007f35aac24850 2025.09.09 15:07:00.162577 [ 3235 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:07:00.300875 [ 3612 ] {f31907fa-b6da-4e94-be6d-591204b8dcc4} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=9, jobs=0): (while reading column key_column): (while reading from part /var/lib/clickhouse/store/cab/cabf9a66-80e2-4148-8335-3c53187f5a8a/all_1_1_0/ in table database_for_dict.table_for_dict (cabf9a66-80e2-4148-8335-3c53187f5a8a) located on disk default of type local, from mark 0 with max_rows_to_read = 1): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder): while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45406) (comment: 01542_dictionary_load_exception_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af80b71 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80746 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000266005a2 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000265fffb4 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:1197: ? @ 0x00000000265fd4e7 9. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:62: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x00000000265e6fbd 10. ./contrib/llvm-project/libcxx/include/future:1123: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x00000000265e7bb3 11. DB::ReadBuffer::next() @ 0x000000000b528aeb 12. ./src/IO/ReadBuffer.h:0: DB::CompressedReadBufferBase::readCompressedDataBlockForAsynchronous(unsigned long&, unsigned long&) @ 0x0000000027760e7f 13. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:110: DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x0000000027764c41 14. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:222: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x0000000027b97730 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 @ 0x0000000027aa00db 16. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:0: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x000000002c7b254b 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7eb79e 18. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:118: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7c9d8a 19. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x000000002c7e0473 20. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x000000002c7dbec3 21. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:0: DB::MergeTreeReadTask::read(DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002c82d05b 22. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:53: DB::MergeTreeInOrderSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&, DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002dea5374 23. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:0: DB::MergeTreeSelectProcessor::read() @ 0x000000002c8242f9 24. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000002de6d77a 25. ./build_docker/./src/Processors/ISource.cpp:0: DB::ISource::work() @ 0x000000002d3290a1 26. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 27. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 28. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 29. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 30. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 31. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 2025.09.09 15:07:00.302773 [ 3612 ] {f31907fa-b6da-4e94-be6d-591204b8dcc4} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=9, jobs=0): (while reading column key_column): (while reading from part /var/lib/clickhouse/store/cab/cabf9a66-80e2-4148-8335-3c53187f5a8a/all_1_1_0/ in table database_for_dict.table_for_dict (cabf9a66-80e2-4148-8335-3c53187f5a8a) located on disk default of type local, from mark 0 with max_rows_to_read = 1): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder): while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af80b71 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80746 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000266005a2 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000265fffb4 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:1197: ? @ 0x00000000265fd4e7 9. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:62: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x00000000265e6fbd 10. ./contrib/llvm-project/libcxx/include/future:1123: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x00000000265e7bb3 11. DB::ReadBuffer::next() @ 0x000000000b528aeb 12. ./src/IO/ReadBuffer.h:0: DB::CompressedReadBufferBase::readCompressedDataBlockForAsynchronous(unsigned long&, unsigned long&) @ 0x0000000027760e7f 13. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:110: DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x0000000027764c41 14. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:222: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x0000000027b97730 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 @ 0x0000000027aa00db 16. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:0: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x000000002c7b254b 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7eb79e 18. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:118: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7c9d8a 19. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x000000002c7e0473 20. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x000000002c7dbec3 21. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:0: DB::MergeTreeReadTask::read(DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002c82d05b 22. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:53: DB::MergeTreeInOrderSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&, DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002dea5374 23. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:0: DB::MergeTreeSelectProcessor::read() @ 0x000000002c8242f9 24. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000002de6d77a 25. ./build_docker/./src/Processors/ISource.cpp:0: DB::ISource::work() @ 0x000000002d3290a1 26. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 27. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 28. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 29. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 30. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 31. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 2025.09.09 15:07:00.331790 [ 20338 ] {1648396a-9864-450a-ba13-7ca9539f0a61} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=9, jobs=0): (while reading column key_column): (while reading from part /var/lib/clickhouse/store/cab/cabf9a66-80e2-4148-8335-3c53187f5a8a/all_1_1_0/ in table database_for_dict.table_for_dict (cabf9a66-80e2-4148-8335-3c53187f5a8a) located on disk default of type local, from mark 0 with max_rows_to_read = 1): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder): while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45440) (comment: 01542_dictionary_load_exception_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af80b71 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80746 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000266005a2 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000265fffb4 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:1197: ? @ 0x00000000265fd4e7 9. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:62: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x00000000265e6fbd 10. ./contrib/llvm-project/libcxx/include/future:1123: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x00000000265e7bb3 11. DB::ReadBuffer::next() @ 0x000000000b528aeb 12. ./src/IO/ReadBuffer.h:0: DB::CompressedReadBufferBase::readCompressedDataBlockForAsynchronous(unsigned long&, unsigned long&) @ 0x0000000027760e7f 13. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:110: DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x0000000027764c41 14. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:222: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x0000000027b97730 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 @ 0x0000000027aa00db 16. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:0: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x000000002c7b254b 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7eb79e 18. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:118: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7c9d8a 19. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x000000002c7e0473 20. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x000000002c7dbec3 21. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:0: DB::MergeTreeReadTask::read(DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002c82d05b 22. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:53: DB::MergeTreeInOrderSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&, DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002dea5374 23. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:0: DB::MergeTreeSelectProcessor::read() @ 0x000000002c8242f9 24. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000002de6d77a 25. ./build_docker/./src/Processors/ISource.cpp:0: DB::ISource::work() @ 0x000000002d3290a1 26. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 27. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 28. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 29. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 30. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 31. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 2025.09.09 15:07:00.334361 [ 20338 ] {1648396a-9864-450a-ba13-7ca9539f0a61} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=9, jobs=0): (while reading column key_column): (while reading from part /var/lib/clickhouse/store/cab/cabf9a66-80e2-4148-8335-3c53187f5a8a/all_1_1_0/ in table database_for_dict.table_for_dict (cabf9a66-80e2-4148-8335-3c53187f5a8a) located on disk default of type local, from mark 0 with max_rows_to_read = 1): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder): while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af80b71 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80746 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000266005a2 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000265fffb4 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:1197: ? @ 0x00000000265fd4e7 9. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:62: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x00000000265e6fbd 10. ./contrib/llvm-project/libcxx/include/future:1123: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x00000000265e7bb3 11. DB::ReadBuffer::next() @ 0x000000000b528aeb 12. ./src/IO/ReadBuffer.h:0: DB::CompressedReadBufferBase::readCompressedDataBlockForAsynchronous(unsigned long&, unsigned long&) @ 0x0000000027760e7f 13. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:110: DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x0000000027764c41 14. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:222: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x0000000027b97730 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 @ 0x0000000027aa00db 16. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:0: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x000000002c7b254b 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7eb79e 18. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:118: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7c9d8a 19. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x000000002c7e0473 20. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x000000002c7dbec3 21. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:0: DB::MergeTreeReadTask::read(DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002c82d05b 22. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:53: DB::MergeTreeInOrderSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&, DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002dea5374 23. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:0: DB::MergeTreeSelectProcessor::read() @ 0x000000002c8242f9 24. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000002de6d77a 25. ./build_docker/./src/Processors/ISource.cpp:0: DB::ISource::work() @ 0x000000002d3290a1 26. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 27. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 28. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 29. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 30. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 31. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 2025.09.09 15:07:00.347231 [ 2688 ] {3084a3e2-3969-4619-b356-a2b1dbe58782} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=9, jobs=0): (while reading column key_column): (while reading from part /var/lib/clickhouse/store/cab/cabf9a66-80e2-4148-8335-3c53187f5a8a/all_1_1_0/ in table database_for_dict.table_for_dict (cabf9a66-80e2-4148-8335-3c53187f5a8a) located on disk default of type local, from mark 0 with max_rows_to_read = 1): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder): while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45438) (comment: 01542_dictionary_load_exception_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af80b71 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80746 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000266005a2 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000265fffb4 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:1197: ? @ 0x00000000265fd4e7 9. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:62: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x00000000265e6fbd 10. ./contrib/llvm-project/libcxx/include/future:1123: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x00000000265e7bb3 11. DB::ReadBuffer::next() @ 0x000000000b528aeb 12. ./src/IO/ReadBuffer.h:0: DB::CompressedReadBufferBase::readCompressedDataBlockForAsynchronous(unsigned long&, unsigned long&) @ 0x0000000027760e7f 13. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:110: DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x0000000027764c41 14. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:222: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x0000000027b97730 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 @ 0x0000000027aa00db 16. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:0: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x000000002c7b254b 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7eb79e 18. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:118: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7c9d8a 19. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x000000002c7e0473 20. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x000000002c7dbec3 21. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:0: DB::MergeTreeReadTask::read(DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002c82d05b 22. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:53: DB::MergeTreeInOrderSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&, DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002dea5374 23. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:0: DB::MergeTreeSelectProcessor::read() @ 0x000000002c8242f9 24. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000002de6d77a 25. ./build_docker/./src/Processors/ISource.cpp:0: DB::ISource::work() @ 0x000000002d3290a1 26. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 27. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 28. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 29. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 30. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 31. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 2025.09.09 15:07:00.349582 [ 2688 ] {3084a3e2-3969-4619-b356-a2b1dbe58782} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=9, jobs=0): (while reading column key_column): (while reading from part /var/lib/clickhouse/store/cab/cabf9a66-80e2-4148-8335-3c53187f5a8a/all_1_1_0/ in table database_for_dict.table_for_dict (cabf9a66-80e2-4148-8335-3c53187f5a8a) located on disk default of type local, from mark 0 with max_rows_to_read = 1): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder): while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af80b71 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80746 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000266005a2 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000265fffb4 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:1197: ? @ 0x00000000265fd4e7 9. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:62: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x00000000265e6fbd 10. ./contrib/llvm-project/libcxx/include/future:1123: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x00000000265e7bb3 11. DB::ReadBuffer::next() @ 0x000000000b528aeb 12. ./src/IO/ReadBuffer.h:0: DB::CompressedReadBufferBase::readCompressedDataBlockForAsynchronous(unsigned long&, unsigned long&) @ 0x0000000027760e7f 13. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:110: DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x0000000027764c41 14. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:222: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x0000000027b97730 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 @ 0x0000000027aa00db 16. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:0: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x000000002c7b254b 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7eb79e 18. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:118: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7c9d8a 19. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x000000002c7e0473 20. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x000000002c7dbec3 21. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:0: DB::MergeTreeReadTask::read(DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002c82d05b 22. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:53: DB::MergeTreeInOrderSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&, DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002dea5374 23. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:0: DB::MergeTreeSelectProcessor::read() @ 0x000000002c8242f9 24. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000002de6d77a 25. ./build_docker/./src/Processors/ISource.cpp:0: DB::ISource::work() @ 0x000000002d3290a1 26. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 27. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 28. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 29. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 30. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 31. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 2025.09.09 15:07:00.361885 [ 20849 ] {02de3814-77c6-4aec-906d-480cb8c53af9} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=9, jobs=0): (while reading column key_column): (while reading from part /var/lib/clickhouse/store/cab/cabf9a66-80e2-4148-8335-3c53187f5a8a/all_1_1_0/ in table database_for_dict.table_for_dict (cabf9a66-80e2-4148-8335-3c53187f5a8a) located on disk default of type local, from mark 0 with max_rows_to_read = 1): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder): while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45392) (comment: 01542_dictionary_load_exception_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af80b71 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80746 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000266005a2 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000265fffb4 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:1197: ? @ 0x00000000265fd4e7 9. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:62: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x00000000265e6fbd 10. ./contrib/llvm-project/libcxx/include/future:1123: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x00000000265e7bb3 11. DB::ReadBuffer::next() @ 0x000000000b528aeb 12. ./src/IO/ReadBuffer.h:0: DB::CompressedReadBufferBase::readCompressedDataBlockForAsynchronous(unsigned long&, unsigned long&) @ 0x0000000027760e7f 13. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:110: DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x0000000027764c41 14. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:222: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x0000000027b97730 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 @ 0x0000000027aa00db 16. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:0: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x000000002c7b254b 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7eb79e 18. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:118: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7c9d8a 19. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x000000002c7e0473 20. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x000000002c7dbec3 21. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:0: DB::MergeTreeReadTask::read(DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002c82d05b 22. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:53: DB::MergeTreeInOrderSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&, DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002dea5374 23. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:0: DB::MergeTreeSelectProcessor::read() @ 0x000000002c8242f9 24. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000002de6d77a 25. ./build_docker/./src/Processors/ISource.cpp:0: DB::ISource::work() @ 0x000000002d3290a1 26. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 27. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 28. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 29. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 30. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 31. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 2025.09.09 15:07:00.363719 [ 20849 ] {02de3814-77c6-4aec-906d-480cb8c53af9} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=9, jobs=0): (while reading column key_column): (while reading from part /var/lib/clickhouse/store/cab/cabf9a66-80e2-4148-8335-3c53187f5a8a/all_1_1_0/ in table database_for_dict.table_for_dict (cabf9a66-80e2-4148-8335-3c53187f5a8a) located on disk default of type local, from mark 0 with max_rows_to_read = 1): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder): while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af80b71 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80746 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000266005a2 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000265fffb4 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:1197: ? @ 0x00000000265fd4e7 9. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:62: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x00000000265e6fbd 10. ./contrib/llvm-project/libcxx/include/future:1123: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x00000000265e7bb3 11. DB::ReadBuffer::next() @ 0x000000000b528aeb 12. ./src/IO/ReadBuffer.h:0: DB::CompressedReadBufferBase::readCompressedDataBlockForAsynchronous(unsigned long&, unsigned long&) @ 0x0000000027760e7f 13. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:110: DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x0000000027764c41 14. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:222: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x0000000027b97730 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 @ 0x0000000027aa00db 16. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:0: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x000000002c7b254b 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7eb79e 18. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:118: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7c9d8a 19. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x000000002c7e0473 20. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x000000002c7dbec3 21. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:0: DB::MergeTreeReadTask::read(DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002c82d05b 22. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:53: DB::MergeTreeInOrderSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&, DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002dea5374 23. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:0: DB::MergeTreeSelectProcessor::read() @ 0x000000002c8242f9 24. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000002de6d77a 25. ./build_docker/./src/Processors/ISource.cpp:0: DB::ISource::work() @ 0x000000002d3290a1 26. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 27. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 28. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 29. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 30. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 31. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 2025.09.09 15:07:00.377476 [ 20397 ] {51c61450-60e8-42e5-bdad-034609667fb5} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=9, jobs=0): (while reading column key_column): (while reading from part /var/lib/clickhouse/store/cab/cabf9a66-80e2-4148-8335-3c53187f5a8a/all_1_1_0/ in table database_for_dict.table_for_dict (cabf9a66-80e2-4148-8335-3c53187f5a8a) located on disk default of type local, from mark 0 with max_rows_to_read = 1): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder): while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45450) (comment: 01542_dictionary_load_exception_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af80b71 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80746 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000266005a2 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000265fffb4 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:1197: ? @ 0x00000000265fd4e7 9. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:62: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x00000000265e6fbd 10. ./contrib/llvm-project/libcxx/include/future:1123: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x00000000265e7bb3 11. DB::ReadBuffer::next() @ 0x000000000b528aeb 12. ./src/IO/ReadBuffer.h:0: DB::CompressedReadBufferBase::readCompressedDataBlockForAsynchronous(unsigned long&, unsigned long&) @ 0x0000000027760e7f 13. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:110: DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x0000000027764c41 14. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:222: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x0000000027b97730 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 @ 0x0000000027aa00db 16. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:0: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x000000002c7b254b 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7eb79e 18. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:118: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7c9d8a 19. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x000000002c7e0473 20. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x000000002c7dbec3 21. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:0: DB::MergeTreeReadTask::read(DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002c82d05b 22. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:53: DB::MergeTreeInOrderSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&, DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002dea5374 23. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:0: DB::MergeTreeSelectProcessor::read() @ 0x000000002c8242f9 24. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000002de6d77a 25. ./build_docker/./src/Processors/ISource.cpp:0: DB::ISource::work() @ 0x000000002d3290a1 26. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 27. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 28. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 29. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 30. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 31. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 2025.09.09 15:07:00.387940 [ 20397 ] {51c61450-60e8-42e5-bdad-034609667fb5} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=9, jobs=0): (while reading column key_column): (while reading from part /var/lib/clickhouse/store/cab/cabf9a66-80e2-4148-8335-3c53187f5a8a/all_1_1_0/ in table database_for_dict.table_for_dict (cabf9a66-80e2-4148-8335-3c53187f5a8a) located on disk default of type local, from mark 0 with max_rows_to_read = 1): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder): while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af80b71 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80746 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000266005a2 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000265fffb4 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:1197: ? @ 0x00000000265fd4e7 9. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:62: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x00000000265e6fbd 10. ./contrib/llvm-project/libcxx/include/future:1123: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x00000000265e7bb3 11. DB::ReadBuffer::next() @ 0x000000000b528aeb 12. ./src/IO/ReadBuffer.h:0: DB::CompressedReadBufferBase::readCompressedDataBlockForAsynchronous(unsigned long&, unsigned long&) @ 0x0000000027760e7f 13. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:110: DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x0000000027764c41 14. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:222: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x0000000027b97730 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 @ 0x0000000027aa00db 16. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:0: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x000000002c7b254b 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7eb79e 18. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:118: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7c9d8a 19. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x000000002c7e0473 20. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x000000002c7dbec3 21. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:0: DB::MergeTreeReadTask::read(DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002c82d05b 22. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:53: DB::MergeTreeInOrderSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&, DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002dea5374 23. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:0: DB::MergeTreeSelectProcessor::read() @ 0x000000002c8242f9 24. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000002de6d77a 25. ./build_docker/./src/Processors/ISource.cpp:0: DB::ISource::work() @ 0x000000002d3290a1 26. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 27. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 28. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 29. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 30. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 31. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 2025.09.09 15:07:00.447012 [ 20881 ] {d1ade7d2-c04e-4ebc-98b5-eed2ebf9b2c0} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=9, jobs=0): (while reading column key_column): (while reading from part /var/lib/clickhouse/store/cab/cabf9a66-80e2-4148-8335-3c53187f5a8a/all_1_1_0/ in table database_for_dict.table_for_dict (cabf9a66-80e2-4148-8335-3c53187f5a8a) located on disk default of type local, from mark 0 with max_rows_to_read = 1): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder): while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45412) (comment: 01542_dictionary_load_exception_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af80b71 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80746 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000266005a2 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000265fffb4 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:1197: ? @ 0x00000000265fd4e7 9. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:62: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x00000000265e6fbd 10. ./contrib/llvm-project/libcxx/include/future:1123: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x00000000265e7bb3 11. DB::ReadBuffer::next() @ 0x000000000b528aeb 12. ./src/IO/ReadBuffer.h:0: DB::CompressedReadBufferBase::readCompressedDataBlockForAsynchronous(unsigned long&, unsigned long&) @ 0x0000000027760e7f 13. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:110: DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x0000000027764c41 14. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:222: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x0000000027b97730 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 @ 0x0000000027aa00db 16. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:0: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x000000002c7b254b 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7eb79e 18. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:118: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7c9d8a 19. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x000000002c7e0473 20. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x000000002c7dbec3 21. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:0: DB::MergeTreeReadTask::read(DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002c82d05b 22. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:53: DB::MergeTreeInOrderSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&, DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002dea5374 23. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:0: DB::MergeTreeSelectProcessor::read() @ 0x000000002c8242f9 24. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000002de6d77a 25. ./build_docker/./src/Processors/ISource.cpp:0: DB::ISource::work() @ 0x000000002d3290a1 26. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 27. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 28. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 29. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 30. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 31. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 2025.09.09 15:07:00.448810 [ 20881 ] {d1ade7d2-c04e-4ebc-98b5-eed2ebf9b2c0} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=9, jobs=0): (while reading column key_column): (while reading from part /var/lib/clickhouse/store/cab/cabf9a66-80e2-4148-8335-3c53187f5a8a/all_1_1_0/ in table database_for_dict.table_for_dict (cabf9a66-80e2-4148-8335-3c53187f5a8a) located on disk default of type local, from mark 0 with max_rows_to_read = 1): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder): while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af80b71 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80746 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000266005a2 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000265fffb4 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:1197: ? @ 0x00000000265fd4e7 9. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:62: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x00000000265e6fbd 10. ./contrib/llvm-project/libcxx/include/future:1123: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x00000000265e7bb3 11. DB::ReadBuffer::next() @ 0x000000000b528aeb 12. ./src/IO/ReadBuffer.h:0: DB::CompressedReadBufferBase::readCompressedDataBlockForAsynchronous(unsigned long&, unsigned long&) @ 0x0000000027760e7f 13. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:110: DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x0000000027764c41 14. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:222: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x0000000027b97730 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 @ 0x0000000027aa00db 16. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:0: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x000000002c7b254b 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7eb79e 18. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:118: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7c9d8a 19. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x000000002c7e0473 20. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x000000002c7dbec3 21. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:0: DB::MergeTreeReadTask::read(DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002c82d05b 22. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:53: DB::MergeTreeInOrderSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&, DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002dea5374 23. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:0: DB::MergeTreeSelectProcessor::read() @ 0x000000002c8242f9 24. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000002de6d77a 25. ./build_docker/./src/Processors/ISource.cpp:0: DB::ISource::work() @ 0x000000002d3290a1 26. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 27. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 28. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 29. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 30. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 31. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 2025.09.09 15:07:00.511710 [ 20882 ] {6d06dce4-5201-4fa7-85dc-5a1940e541c5} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=9, jobs=0): (while reading column key_column): (while reading from part /var/lib/clickhouse/store/cab/cabf9a66-80e2-4148-8335-3c53187f5a8a/all_1_1_0/ in table database_for_dict.table_for_dict (cabf9a66-80e2-4148-8335-3c53187f5a8a) located on disk default of type local, from mark 0 with max_rows_to_read = 1): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder): while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45422) (comment: 01542_dictionary_load_exception_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af80b71 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80746 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000266005a2 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000265fffb4 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:1197: ? @ 0x00000000265fd4e7 9. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:62: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x00000000265e6fbd 10. ./contrib/llvm-project/libcxx/include/future:1123: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x00000000265e7bb3 11. DB::ReadBuffer::next() @ 0x000000000b528aeb 12. ./src/IO/ReadBuffer.h:0: DB::CompressedReadBufferBase::readCompressedDataBlockForAsynchronous(unsigned long&, unsigned long&) @ 0x0000000027760e7f 13. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:110: DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x0000000027764c41 14. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:222: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x0000000027b97730 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 @ 0x0000000027aa00db 16. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:0: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x000000002c7b254b 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7eb79e 18. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:118: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7c9d8a 19. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x000000002c7e0473 20. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x000000002c7dbec3 21. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:0: DB::MergeTreeReadTask::read(DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002c82d05b 22. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:53: DB::MergeTreeInOrderSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&, DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002dea5374 23. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:0: DB::MergeTreeSelectProcessor::read() @ 0x000000002c8242f9 24. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000002de6d77a 25. ./build_docker/./src/Processors/ISource.cpp:0: DB::ISource::work() @ 0x000000002d3290a1 26. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 27. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 28. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 29. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 30. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 31. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 2025.09.09 15:07:00.519049 [ 2793 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:07:00.519195 [ 2783 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:07:00.526627 [ 20882 ] {6d06dce4-5201-4fa7-85dc-5a1940e541c5} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=9, jobs=0): (while reading column key_column): (while reading from part /var/lib/clickhouse/store/cab/cabf9a66-80e2-4148-8335-3c53187f5a8a/all_1_1_0/ in table database_for_dict.table_for_dict (cabf9a66-80e2-4148-8335-3c53187f5a8a) located on disk default of type local, from mark 0 with max_rows_to_read = 1): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder): while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af80b71 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80746 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000266005a2 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000265fffb4 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:1197: ? @ 0x00000000265fd4e7 9. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:62: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x00000000265e6fbd 10. ./contrib/llvm-project/libcxx/include/future:1123: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x00000000265e7bb3 11. DB::ReadBuffer::next() @ 0x000000000b528aeb 12. ./src/IO/ReadBuffer.h:0: DB::CompressedReadBufferBase::readCompressedDataBlockForAsynchronous(unsigned long&, unsigned long&) @ 0x0000000027760e7f 13. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:110: DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x0000000027764c41 14. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:222: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x0000000027b97730 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 @ 0x0000000027aa00db 16. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:0: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x000000002c7b254b 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7eb79e 18. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:118: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7c9d8a 19. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x000000002c7e0473 20. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x000000002c7dbec3 21. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:0: DB::MergeTreeReadTask::read(DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002c82d05b 22. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:53: DB::MergeTreeInOrderSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&, DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002dea5374 23. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:0: DB::MergeTreeSelectProcessor::read() @ 0x000000002c8242f9 24. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000002de6d77a 25. ./build_docker/./src/Processors/ISource.cpp:0: DB::ISource::work() @ 0x000000002d3290a1 26. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 27. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 28. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 29. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 30. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 31. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 2025.09.09 15:07:00.594075 [ 19252 ] {bc1847ba-a9f8-42bc-9a7b-ff3c7c034b8e} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=9, jobs=0): (while reading column key_column): (while reading from part /var/lib/clickhouse/store/cab/cabf9a66-80e2-4148-8335-3c53187f5a8a/all_1_1_0/ in table database_for_dict.table_for_dict (cabf9a66-80e2-4148-8335-3c53187f5a8a) located on disk default of type local, from mark 0 with max_rows_to_read = 1): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder): while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45466) (comment: 01542_dictionary_load_exception_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af80b71 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80746 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000266005a2 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000265fffb4 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:1197: ? @ 0x00000000265fd4e7 9. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:62: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x00000000265e6fbd 10. ./contrib/llvm-project/libcxx/include/future:1123: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x00000000265e7bb3 11. DB::ReadBuffer::next() @ 0x000000000b528aeb 12. ./src/IO/ReadBuffer.h:0: DB::CompressedReadBufferBase::readCompressedDataBlockForAsynchronous(unsigned long&, unsigned long&) @ 0x0000000027760e7f 13. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:110: DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x0000000027764c41 14. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:222: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x0000000027b97730 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 @ 0x0000000027aa00db 16. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:0: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x000000002c7b254b 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7eb79e 18. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:118: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7c9d8a 19. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x000000002c7e0473 20. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x000000002c7dbec3 21. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:0: DB::MergeTreeReadTask::read(DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002c82d05b 22. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:53: DB::MergeTreeInOrderSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&, DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002dea5374 23. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:0: DB::MergeTreeSelectProcessor::read() @ 0x000000002c8242f9 24. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000002de6d77a 25. ./build_docker/./src/Processors/ISource.cpp:0: DB::ISource::work() @ 0x000000002d3290a1 26. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 27. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 28. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 29. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 30. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 31. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 2025.09.09 15:07:00.596020 [ 19252 ] {bc1847ba-a9f8-42bc-9a7b-ff3c7c034b8e} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=9, jobs=0): (while reading column key_column): (while reading from part /var/lib/clickhouse/store/cab/cabf9a66-80e2-4148-8335-3c53187f5a8a/all_1_1_0/ in table database_for_dict.table_for_dict (cabf9a66-80e2-4148-8335-3c53187f5a8a) located on disk default of type local, from mark 0 with max_rows_to_read = 1): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder): while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af80b71 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80746 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000266005a2 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000265fffb4 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:1197: ? @ 0x00000000265fd4e7 9. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:62: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x00000000265e6fbd 10. ./contrib/llvm-project/libcxx/include/future:1123: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x00000000265e7bb3 11. DB::ReadBuffer::next() @ 0x000000000b528aeb 12. ./src/IO/ReadBuffer.h:0: DB::CompressedReadBufferBase::readCompressedDataBlockForAsynchronous(unsigned long&, unsigned long&) @ 0x0000000027760e7f 13. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:110: DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x0000000027764c41 14. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:222: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x0000000027b97730 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 @ 0x0000000027aa00db 16. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:0: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x000000002c7b254b 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7eb79e 18. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:118: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7c9d8a 19. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x000000002c7e0473 20. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x000000002c7dbec3 21. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:0: DB::MergeTreeReadTask::read(DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002c82d05b 22. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:53: DB::MergeTreeInOrderSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&, DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002dea5374 23. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:0: DB::MergeTreeSelectProcessor::read() @ 0x000000002c8242f9 24. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000002de6d77a 25. ./build_docker/./src/Processors/ISource.cpp:0: DB::ISource::work() @ 0x000000002d3290a1 26. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 27. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 28. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 29. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 30. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 31. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 2025.09.09 15:07:00.619017 [ 2797 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:07:00.621281 [ 20343 ] {e2d20355-610b-428c-9a17-20dd9c688da2} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=9, jobs=0): (while reading column key_column): (while reading from part /var/lib/clickhouse/store/cab/cabf9a66-80e2-4148-8335-3c53187f5a8a/all_1_1_0/ in table database_for_dict.table_for_dict (cabf9a66-80e2-4148-8335-3c53187f5a8a) located on disk default of type local, from mark 0 with max_rows_to_read = 1): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder): while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45472) (comment: 01542_dictionary_load_exception_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af80b71 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80746 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000266005a2 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000265fffb4 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:1197: ? @ 0x00000000265fd4e7 9. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:62: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x00000000265e6fbd 10. ./contrib/llvm-project/libcxx/include/future:1123: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x00000000265e7bb3 11. DB::ReadBuffer::next() @ 0x000000000b528aeb 12. ./src/IO/ReadBuffer.h:0: DB::CompressedReadBufferBase::readCompressedDataBlockForAsynchronous(unsigned long&, unsigned long&) @ 0x0000000027760e7f 13. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:110: DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x0000000027764c41 14. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:222: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x0000000027b97730 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 @ 0x0000000027aa00db 16. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:0: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x000000002c7b254b 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7eb79e 18. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:118: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7c9d8a 19. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x000000002c7e0473 20. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x000000002c7dbec3 21. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:0: DB::MergeTreeReadTask::read(DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002c82d05b 22. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:53: DB::MergeTreeInOrderSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&, DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002dea5374 23. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:0: DB::MergeTreeSelectProcessor::read() @ 0x000000002c8242f9 24. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000002de6d77a 25. ./build_docker/./src/Processors/ISource.cpp:0: DB::ISource::work() @ 0x000000002d3290a1 26. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 27. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 28. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 29. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 30. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 31. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 2025.09.09 15:07:00.633188 [ 20343 ] {e2d20355-610b-428c-9a17-20dd9c688da2} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=9, jobs=0): (while reading column key_column): (while reading from part /var/lib/clickhouse/store/cab/cabf9a66-80e2-4148-8335-3c53187f5a8a/all_1_1_0/ in table database_for_dict.table_for_dict (cabf9a66-80e2-4148-8335-3c53187f5a8a) located on disk default of type local, from mark 0 with max_rows_to_read = 1): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder): while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af80b71 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80746 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000266005a2 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000265fffb4 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:1197: ? @ 0x00000000265fd4e7 9. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:62: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x00000000265e6fbd 10. ./contrib/llvm-project/libcxx/include/future:1123: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x00000000265e7bb3 11. DB::ReadBuffer::next() @ 0x000000000b528aeb 12. ./src/IO/ReadBuffer.h:0: DB::CompressedReadBufferBase::readCompressedDataBlockForAsynchronous(unsigned long&, unsigned long&) @ 0x0000000027760e7f 13. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:110: DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x0000000027764c41 14. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:222: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x0000000027b97730 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 @ 0x0000000027aa00db 16. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:0: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x000000002c7b254b 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7eb79e 18. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:118: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7c9d8a 19. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x000000002c7e0473 20. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x000000002c7dbec3 21. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:0: DB::MergeTreeReadTask::read(DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002c82d05b 22. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:53: DB::MergeTreeInOrderSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&, DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002dea5374 23. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:0: DB::MergeTreeSelectProcessor::read() @ 0x000000002c8242f9 24. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000002de6d77a 25. ./build_docker/./src/Processors/ISource.cpp:0: DB::ISource::work() @ 0x000000002d3290a1 26. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 27. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 28. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 29. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 30. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 31. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 2025.09.09 15:07:00.806660 [ 2688 ] {edde4bd1-ee34-40da-ae93-1bcc10e729a8} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=9, jobs=0): (while reading column key_column): (while reading from part /var/lib/clickhouse/store/cab/cabf9a66-80e2-4148-8335-3c53187f5a8a/all_1_1_0/ in table database_for_dict.table_for_dict (cabf9a66-80e2-4148-8335-3c53187f5a8a) located on disk default of type local, from mark 0 with max_rows_to_read = 1): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder): while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45494) (comment: 01542_dictionary_load_exception_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af80b71 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80746 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000266005a2 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000265fffb4 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:1197: ? @ 0x00000000265fd4e7 9. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:62: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x00000000265e6fbd 10. ./contrib/llvm-project/libcxx/include/future:1123: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x00000000265e7bb3 11. DB::ReadBuffer::next() @ 0x000000000b528aeb 12. ./src/IO/ReadBuffer.h:0: DB::CompressedReadBufferBase::readCompressedDataBlockForAsynchronous(unsigned long&, unsigned long&) @ 0x0000000027760e7f 13. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:110: DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x0000000027764c41 14. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:222: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x0000000027b97730 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 @ 0x0000000027aa00db 16. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:0: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x000000002c7b254b 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7eb79e 18. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:118: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7c9d8a 19. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x000000002c7e0473 20. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x000000002c7dbec3 21. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:0: DB::MergeTreeReadTask::read(DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002c82d05b 22. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:53: DB::MergeTreeInOrderSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&, DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002dea5374 23. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:0: DB::MergeTreeSelectProcessor::read() @ 0x000000002c8242f9 24. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000002de6d77a 25. ./build_docker/./src/Processors/ISource.cpp:0: DB::ISource::work() @ 0x000000002d3290a1 26. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 27. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 28. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 29. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 30. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 31. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 2025.09.09 15:07:00.818446 [ 2688 ] {edde4bd1-ee34-40da-ae93-1bcc10e729a8} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=9, jobs=0): (while reading column key_column): (while reading from part /var/lib/clickhouse/store/cab/cabf9a66-80e2-4148-8335-3c53187f5a8a/all_1_1_0/ in table database_for_dict.table_for_dict (cabf9a66-80e2-4148-8335-3c53187f5a8a) located on disk default of type local, from mark 0 with max_rows_to_read = 1): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder): while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af80b71 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80746 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000266005a2 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000265fffb4 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:1197: ? @ 0x00000000265fd4e7 9. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:62: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x00000000265e6fbd 10. ./contrib/llvm-project/libcxx/include/future:1123: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x00000000265e7bb3 11. DB::ReadBuffer::next() @ 0x000000000b528aeb 12. ./src/IO/ReadBuffer.h:0: DB::CompressedReadBufferBase::readCompressedDataBlockForAsynchronous(unsigned long&, unsigned long&) @ 0x0000000027760e7f 13. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:110: DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x0000000027764c41 14. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:222: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x0000000027b97730 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 @ 0x0000000027aa00db 16. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:0: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x000000002c7b254b 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7eb79e 18. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:118: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7c9d8a 19. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x000000002c7e0473 20. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x000000002c7dbec3 21. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:0: DB::MergeTreeReadTask::read(DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002c82d05b 22. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:53: DB::MergeTreeInOrderSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&, DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002dea5374 23. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:0: DB::MergeTreeSelectProcessor::read() @ 0x000000002c8242f9 24. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000002de6d77a 25. ./build_docker/./src/Processors/ISource.cpp:0: DB::ISource::work() @ 0x000000002d3290a1 26. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 27. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 28. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 29. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 30. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 31. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 2025.09.09 15:07:00.825906 [ 20882 ] {ffcb48dd-46e4-4bc6-b499-4b637c5df7c0} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=9, jobs=0): (while reading column key_column): (while reading from part /var/lib/clickhouse/store/cab/cabf9a66-80e2-4148-8335-3c53187f5a8a/all_1_1_0/ in table database_for_dict.table_for_dict (cabf9a66-80e2-4148-8335-3c53187f5a8a) located on disk default of type local, from mark 0 with max_rows_to_read = 1): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder): while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45498) (comment: 01542_dictionary_load_exception_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af80b71 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80746 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000266005a2 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000265fffb4 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:1197: ? @ 0x00000000265fd4e7 9. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:62: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x00000000265e6fbd 10. ./contrib/llvm-project/libcxx/include/future:1123: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x00000000265e7bb3 11. DB::ReadBuffer::next() @ 0x000000000b528aeb 12. ./src/IO/ReadBuffer.h:0: DB::CompressedReadBufferBase::readCompressedDataBlockForAsynchronous(unsigned long&, unsigned long&) @ 0x0000000027760e7f 13. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:110: DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x0000000027764c41 14. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:222: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x0000000027b97730 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 @ 0x0000000027aa00db 16. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:0: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x000000002c7b254b 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7eb79e 18. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:118: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7c9d8a 19. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x000000002c7e0473 20. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x000000002c7dbec3 21. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:0: DB::MergeTreeReadTask::read(DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002c82d05b 22. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:53: DB::MergeTreeInOrderSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&, DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002dea5374 23. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:0: DB::MergeTreeSelectProcessor::read() @ 0x000000002c8242f9 24. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000002de6d77a 25. ./build_docker/./src/Processors/ISource.cpp:0: DB::ISource::work() @ 0x000000002d3290a1 26. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 27. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 28. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 29. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 30. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 31. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 2025.09.09 15:07:00.834660 [ 20882 ] {ffcb48dd-46e4-4bc6-b499-4b637c5df7c0} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=9, jobs=0): (while reading column key_column): (while reading from part /var/lib/clickhouse/store/cab/cabf9a66-80e2-4148-8335-3c53187f5a8a/all_1_1_0/ in table database_for_dict.table_for_dict (cabf9a66-80e2-4148-8335-3c53187f5a8a) located on disk default of type local, from mark 0 with max_rows_to_read = 1): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder): while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af80b71 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80746 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000266005a2 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000265fffb4 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:1197: ? @ 0x00000000265fd4e7 9. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:62: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x00000000265e6fbd 10. ./contrib/llvm-project/libcxx/include/future:1123: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x00000000265e7bb3 11. DB::ReadBuffer::next() @ 0x000000000b528aeb 12. ./src/IO/ReadBuffer.h:0: DB::CompressedReadBufferBase::readCompressedDataBlockForAsynchronous(unsigned long&, unsigned long&) @ 0x0000000027760e7f 13. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:110: DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x0000000027764c41 14. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:222: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x0000000027b97730 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 @ 0x0000000027aa00db 16. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:0: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x000000002c7b254b 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7eb79e 18. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:118: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7c9d8a 19. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x000000002c7e0473 20. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x000000002c7dbec3 21. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:0: DB::MergeTreeReadTask::read(DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002c82d05b 22. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:53: DB::MergeTreeInOrderSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&, DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002dea5374 23. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:0: DB::MergeTreeSelectProcessor::read() @ 0x000000002c8242f9 24. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000002de6d77a 25. ./build_docker/./src/Processors/ISource.cpp:0: DB::ISource::work() @ 0x000000002d3290a1 26. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 27. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 28. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 29. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 30. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 31. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 2025.09.09 15:07:00.883589 [ 20881 ] {a0f0b83d-3244-40c4-b4f6-cd8da6a91889} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=9, jobs=0): (while reading column key_column): (while reading from part /var/lib/clickhouse/store/cab/cabf9a66-80e2-4148-8335-3c53187f5a8a/all_1_1_0/ in table database_for_dict.table_for_dict (cabf9a66-80e2-4148-8335-3c53187f5a8a) located on disk default of type local, from mark 0 with max_rows_to_read = 1): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder): while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45484) (comment: 01542_dictionary_load_exception_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af80b71 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80746 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000266005a2 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000265fffb4 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:1197: ? @ 0x00000000265fd4e7 9. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:62: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x00000000265e6fbd 10. ./contrib/llvm-project/libcxx/include/future:1123: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x00000000265e7bb3 11. DB::ReadBuffer::next() @ 0x000000000b528aeb 12. ./src/IO/ReadBuffer.h:0: DB::CompressedReadBufferBase::readCompressedDataBlockForAsynchronous(unsigned long&, unsigned long&) @ 0x0000000027760e7f 13. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:110: DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x0000000027764c41 14. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:222: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x0000000027b97730 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 @ 0x0000000027aa00db 16. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:0: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x000000002c7b254b 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7eb79e 18. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:118: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7c9d8a 19. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x000000002c7e0473 20. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x000000002c7dbec3 21. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:0: DB::MergeTreeReadTask::read(DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002c82d05b 22. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:53: DB::MergeTreeInOrderSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&, DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002dea5374 23. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:0: DB::MergeTreeSelectProcessor::read() @ 0x000000002c8242f9 24. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000002de6d77a 25. ./build_docker/./src/Processors/ISource.cpp:0: DB::ISource::work() @ 0x000000002d3290a1 26. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 27. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 28. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 29. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 30. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 31. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 2025.09.09 15:07:00.885482 [ 20881 ] {a0f0b83d-3244-40c4-b4f6-cd8da6a91889} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=9, jobs=0): (while reading column key_column): (while reading from part /var/lib/clickhouse/store/cab/cabf9a66-80e2-4148-8335-3c53187f5a8a/all_1_1_0/ in table database_for_dict.table_for_dict (cabf9a66-80e2-4148-8335-3c53187f5a8a) located on disk default of type local, from mark 0 with max_rows_to_read = 1): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder): while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af80b71 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80746 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000266005a2 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000265fffb4 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:1197: ? @ 0x00000000265fd4e7 9. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:62: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x00000000265e6fbd 10. ./contrib/llvm-project/libcxx/include/future:1123: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x00000000265e7bb3 11. DB::ReadBuffer::next() @ 0x000000000b528aeb 12. ./src/IO/ReadBuffer.h:0: DB::CompressedReadBufferBase::readCompressedDataBlockForAsynchronous(unsigned long&, unsigned long&) @ 0x0000000027760e7f 13. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:110: DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x0000000027764c41 14. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:222: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x0000000027b97730 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 @ 0x0000000027aa00db 16. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:0: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x000000002c7b254b 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7eb79e 18. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:118: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7c9d8a 19. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x000000002c7e0473 20. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x000000002c7dbec3 21. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:0: DB::MergeTreeReadTask::read(DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002c82d05b 22. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:53: DB::MergeTreeInOrderSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&, DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002dea5374 23. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:0: DB::MergeTreeSelectProcessor::read() @ 0x000000002c8242f9 24. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000002de6d77a 25. ./build_docker/./src/Processors/ISource.cpp:0: DB::ISource::work() @ 0x000000002d3290a1 26. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 27. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 28. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 29. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 30. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 31. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 2025.09.09 15:07:01.092965 [ 20397 ] {880dcc03-c869-4fbb-b54c-b3e34b3c6c23} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=9, jobs=0): (while reading column key_column): (while reading from part /var/lib/clickhouse/store/cab/cabf9a66-80e2-4148-8335-3c53187f5a8a/all_1_1_0/ in table database_for_dict.table_for_dict (cabf9a66-80e2-4148-8335-3c53187f5a8a) located on disk default of type local, from mark 0 with max_rows_to_read = 1): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder): while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45544) (comment: 01542_dictionary_load_exception_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af80b71 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80746 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000266005a2 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000265fffb4 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:1197: ? @ 0x00000000265fd4e7 9. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:62: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x00000000265e6fbd 10. ./contrib/llvm-project/libcxx/include/future:1123: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x00000000265e7bb3 11. DB::ReadBuffer::next() @ 0x000000000b528aeb 12. ./src/IO/ReadBuffer.h:0: DB::CompressedReadBufferBase::readCompressedDataBlockForAsynchronous(unsigned long&, unsigned long&) @ 0x0000000027760e7f 13. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:110: DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x0000000027764c41 14. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:222: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x0000000027b97730 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 @ 0x0000000027aa00db 16. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:0: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x000000002c7b254b 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7eb79e 18. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:118: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7c9d8a 19. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x000000002c7e0473 20. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x000000002c7dbec3 21. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:0: DB::MergeTreeReadTask::read(DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002c82d05b 22. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:53: DB::MergeTreeInOrderSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&, DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002dea5374 23. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:0: DB::MergeTreeSelectProcessor::read() @ 0x000000002c8242f9 24. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000002de6d77a 25. ./build_docker/./src/Processors/ISource.cpp:0: DB::ISource::work() @ 0x000000002d3290a1 26. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 27. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 28. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 29. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 30. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 31. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 2025.09.09 15:07:01.104315 [ 20397 ] {880dcc03-c869-4fbb-b54c-b3e34b3c6c23} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=9, jobs=0): (while reading column key_column): (while reading from part /var/lib/clickhouse/store/cab/cabf9a66-80e2-4148-8335-3c53187f5a8a/all_1_1_0/ in table database_for_dict.table_for_dict (cabf9a66-80e2-4148-8335-3c53187f5a8a) located on disk default of type local, from mark 0 with max_rows_to_read = 1): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder): while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af80b71 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80746 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000266005a2 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000265fffb4 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:1197: ? @ 0x00000000265fd4e7 9. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:62: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x00000000265e6fbd 10. ./contrib/llvm-project/libcxx/include/future:1123: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x00000000265e7bb3 11. DB::ReadBuffer::next() @ 0x000000000b528aeb 12. ./src/IO/ReadBuffer.h:0: DB::CompressedReadBufferBase::readCompressedDataBlockForAsynchronous(unsigned long&, unsigned long&) @ 0x0000000027760e7f 13. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:110: DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x0000000027764c41 14. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:222: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x0000000027b97730 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 @ 0x0000000027aa00db 16. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:0: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x000000002c7b254b 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7eb79e 18. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:118: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7c9d8a 19. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x000000002c7e0473 20. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x000000002c7dbec3 21. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:0: DB::MergeTreeReadTask::read(DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002c82d05b 22. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:53: DB::MergeTreeInOrderSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&, DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002dea5374 23. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:0: DB::MergeTreeSelectProcessor::read() @ 0x000000002c8242f9 24. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000002de6d77a 25. ./build_docker/./src/Processors/ISource.cpp:0: DB::ISource::work() @ 0x000000002d3290a1 26. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 27. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 28. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 29. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 30. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 31. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 2025.09.09 15:07:01.135339 [ 20882 ] {774c59a5-83f6-43af-8e38-371f796114b4} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=790, jobs=735). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45570) (comment: 01542_dictionary_load_exception_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af872f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af7b2d1 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af7c3f3 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d36920d 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000002d369e5f 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processOrdinaryQuery() @ 0x000000002d18af7b 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d17644a 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 15. asan_thread_start(void*) @ 0x000000000aa43059 16. ? @ 0x00007f35aab92ac3 17. ? @ 0x00007f35aac24850 2025.09.09 15:07:01.153756 [ 20882 ] {774c59a5-83f6-43af-8e38-371f796114b4} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=790, 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af872f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af7b2d1 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af7c3f3 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d36920d 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000002d369e5f 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processOrdinaryQuery() @ 0x000000002d18af7b 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d17644a 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 15. asan_thread_start(void*) @ 0x000000000aa43059 16. ? @ 0x00007f35aab92ac3 17. ? @ 0x00007f35aac24850 2025.09.09 15:07:01.164277 [ 2854 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:07:01.166911 [ 2688 ] {347ed2f9-55ec-4add-89c0-a2b282276011} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=9, jobs=0): (while reading column key_column): (while reading from part /var/lib/clickhouse/store/cab/cabf9a66-80e2-4148-8335-3c53187f5a8a/all_1_1_0/ in table database_for_dict.table_for_dict (cabf9a66-80e2-4148-8335-3c53187f5a8a) located on disk default of type local, from mark 0 with max_rows_to_read = 1): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder): while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45558) (comment: 01542_dictionary_load_exception_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af80b71 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80746 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000266005a2 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000265fffb4 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:1197: ? @ 0x00000000265fd4e7 9. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:62: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x00000000265e6fbd 10. ./contrib/llvm-project/libcxx/include/future:1123: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x00000000265e7bb3 11. DB::ReadBuffer::next() @ 0x000000000b528aeb 12. ./src/IO/ReadBuffer.h:0: DB::CompressedReadBufferBase::readCompressedDataBlockForAsynchronous(unsigned long&, unsigned long&) @ 0x0000000027760e7f 13. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:110: DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x0000000027764c41 14. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:222: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x0000000027b97730 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 @ 0x0000000027aa00db 16. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:0: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x000000002c7b254b 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7eb79e 18. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:118: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7c9d8a 19. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x000000002c7e0473 20. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x000000002c7dbec3 21. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:0: DB::MergeTreeReadTask::read(DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002c82d05b 22. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:53: DB::MergeTreeInOrderSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&, DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002dea5374 23. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:0: DB::MergeTreeSelectProcessor::read() @ 0x000000002c8242f9 24. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000002de6d77a 25. ./build_docker/./src/Processors/ISource.cpp:0: DB::ISource::work() @ 0x000000002d3290a1 26. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 27. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 28. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 29. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 30. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 31. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 2025.09.09 15:07:01.168539 [ 2688 ] {347ed2f9-55ec-4add-89c0-a2b282276011} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=9, jobs=0): (while reading column key_column): (while reading from part /var/lib/clickhouse/store/cab/cabf9a66-80e2-4148-8335-3c53187f5a8a/all_1_1_0/ in table database_for_dict.table_for_dict (cabf9a66-80e2-4148-8335-3c53187f5a8a) located on disk default of type local, from mark 0 with max_rows_to_read = 1): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder): while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af80b71 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80746 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000266005a2 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000265fffb4 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:1197: ? @ 0x00000000265fd4e7 9. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:62: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x00000000265e6fbd 10. ./contrib/llvm-project/libcxx/include/future:1123: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x00000000265e7bb3 11. DB::ReadBuffer::next() @ 0x000000000b528aeb 12. ./src/IO/ReadBuffer.h:0: DB::CompressedReadBufferBase::readCompressedDataBlockForAsynchronous(unsigned long&, unsigned long&) @ 0x0000000027760e7f 13. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:110: DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x0000000027764c41 14. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:222: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x0000000027b97730 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 @ 0x0000000027aa00db 16. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:0: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x000000002c7b254b 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7eb79e 18. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:118: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7c9d8a 19. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x000000002c7e0473 20. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x000000002c7dbec3 21. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:0: DB::MergeTreeReadTask::read(DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002c82d05b 22. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:53: DB::MergeTreeInOrderSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&, DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002dea5374 23. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:0: DB::MergeTreeSelectProcessor::read() @ 0x000000002c8242f9 24. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000002de6d77a 25. ./build_docker/./src/Processors/ISource.cpp:0: DB::ISource::work() @ 0x000000002d3290a1 26. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 27. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 28. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 29. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 30. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 31. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 2025.09.09 15:07:01.232150 [ 20343 ] {bce773d9-0693-4870-9a98-08c3a8ea3b73} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=9, jobs=0): (while reading column key_column): (while reading from part /var/lib/clickhouse/store/cab/cabf9a66-80e2-4148-8335-3c53187f5a8a/all_1_1_0/ in table database_for_dict.table_for_dict (cabf9a66-80e2-4148-8335-3c53187f5a8a) located on disk default of type local, from mark 0 with max_rows_to_read = 1): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder): while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45586) (comment: 01542_dictionary_load_exception_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af80b71 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80746 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000266005a2 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000265fffb4 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:1197: ? @ 0x00000000265fd4e7 9. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:62: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x00000000265e6fbd 10. ./contrib/llvm-project/libcxx/include/future:1123: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x00000000265e7bb3 11. DB::ReadBuffer::next() @ 0x000000000b528aeb 12. ./src/IO/ReadBuffer.h:0: DB::CompressedReadBufferBase::readCompressedDataBlockForAsynchronous(unsigned long&, unsigned long&) @ 0x0000000027760e7f 13. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:110: DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x0000000027764c41 14. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:222: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x0000000027b97730 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 @ 0x0000000027aa00db 16. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:0: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x000000002c7b254b 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7eb79e 18. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:118: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7c9d8a 19. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x000000002c7e0473 20. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x000000002c7dbec3 21. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:0: DB::MergeTreeReadTask::read(DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002c82d05b 22. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:53: DB::MergeTreeInOrderSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&, DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002dea5374 23. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:0: DB::MergeTreeSelectProcessor::read() @ 0x000000002c8242f9 24. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000002de6d77a 25. ./build_docker/./src/Processors/ISource.cpp:0: DB::ISource::work() @ 0x000000002d3290a1 26. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 27. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 28. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 29. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 30. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 31. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 2025.09.09 15:07:01.235661 [ 20343 ] {bce773d9-0693-4870-9a98-08c3a8ea3b73} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=9, jobs=0): (while reading column key_column): (while reading from part /var/lib/clickhouse/store/cab/cabf9a66-80e2-4148-8335-3c53187f5a8a/all_1_1_0/ in table database_for_dict.table_for_dict (cabf9a66-80e2-4148-8335-3c53187f5a8a) located on disk default of type local, from mark 0 with max_rows_to_read = 1): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder): while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af80b71 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80746 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000266005a2 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000265fffb4 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:1197: ? @ 0x00000000265fd4e7 9. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:62: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x00000000265e6fbd 10. ./contrib/llvm-project/libcxx/include/future:1123: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x00000000265e7bb3 11. DB::ReadBuffer::next() @ 0x000000000b528aeb 12. ./src/IO/ReadBuffer.h:0: DB::CompressedReadBufferBase::readCompressedDataBlockForAsynchronous(unsigned long&, unsigned long&) @ 0x0000000027760e7f 13. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:110: DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x0000000027764c41 14. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:222: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x0000000027b97730 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 @ 0x0000000027aa00db 16. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:0: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x000000002c7b254b 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7eb79e 18. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:118: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7c9d8a 19. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x000000002c7e0473 20. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x000000002c7dbec3 21. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:0: DB::MergeTreeReadTask::read(DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002c82d05b 22. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:53: DB::MergeTreeInOrderSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&, DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002dea5374 23. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:0: DB::MergeTreeSelectProcessor::read() @ 0x000000002c8242f9 24. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000002de6d77a 25. ./build_docker/./src/Processors/ISource.cpp:0: DB::ISource::work() @ 0x000000002d3290a1 26. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 27. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 28. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 29. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 30. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 31. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 2025.09.09 15:07:01.259879 [ 20338 ] {f53da9c8-1c3b-4ae0-8f16-372876c2fb26} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=9, jobs=0): (while reading column key_column): (while reading from part /var/lib/clickhouse/store/cab/cabf9a66-80e2-4148-8335-3c53187f5a8a/all_1_1_0/ in table database_for_dict.table_for_dict (cabf9a66-80e2-4148-8335-3c53187f5a8a) located on disk default of type local, from mark 0 with max_rows_to_read = 1): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder): while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45530) (comment: 01542_dictionary_load_exception_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af80b71 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80746 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000266005a2 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000265fffb4 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:1197: ? @ 0x00000000265fd4e7 9. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:62: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x00000000265e6fbd 10. ./contrib/llvm-project/libcxx/include/future:1123: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x00000000265e7bb3 11. DB::ReadBuffer::next() @ 0x000000000b528aeb 12. ./src/IO/ReadBuffer.h:0: DB::CompressedReadBufferBase::readCompressedDataBlockForAsynchronous(unsigned long&, unsigned long&) @ 0x0000000027760e7f 13. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:110: DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x0000000027764c41 14. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:222: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x0000000027b97730 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 @ 0x0000000027aa00db 16. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:0: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x000000002c7b254b 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7eb79e 18. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:118: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7c9d8a 19. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x000000002c7e0473 20. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x000000002c7dbec3 21. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:0: DB::MergeTreeReadTask::read(DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002c82d05b 22. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:53: DB::MergeTreeInOrderSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&, DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002dea5374 23. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:0: DB::MergeTreeSelectProcessor::read() @ 0x000000002c8242f9 24. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000002de6d77a 25. ./build_docker/./src/Processors/ISource.cpp:0: DB::ISource::work() @ 0x000000002d3290a1 26. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 27. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 28. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 29. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 30. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 31. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 2025.09.09 15:07:01.261817 [ 20338 ] {f53da9c8-1c3b-4ae0-8f16-372876c2fb26} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=9, jobs=0): (while reading column key_column): (while reading from part /var/lib/clickhouse/store/cab/cabf9a66-80e2-4148-8335-3c53187f5a8a/all_1_1_0/ in table database_for_dict.table_for_dict (cabf9a66-80e2-4148-8335-3c53187f5a8a) located on disk default of type local, from mark 0 with max_rows_to_read = 1): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder): while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af80b71 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80746 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000266005a2 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000265fffb4 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:1197: ? @ 0x00000000265fd4e7 9. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:62: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x00000000265e6fbd 10. ./contrib/llvm-project/libcxx/include/future:1123: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x00000000265e7bb3 11. DB::ReadBuffer::next() @ 0x000000000b528aeb 12. ./src/IO/ReadBuffer.h:0: DB::CompressedReadBufferBase::readCompressedDataBlockForAsynchronous(unsigned long&, unsigned long&) @ 0x0000000027760e7f 13. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:110: DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x0000000027764c41 14. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:222: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x0000000027b97730 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 @ 0x0000000027aa00db 16. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:0: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x000000002c7b254b 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7eb79e 18. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:118: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7c9d8a 19. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x000000002c7e0473 20. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x000000002c7dbec3 21. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:0: DB::MergeTreeReadTask::read(DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002c82d05b 22. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:53: DB::MergeTreeInOrderSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&, DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002dea5374 23. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:0: DB::MergeTreeSelectProcessor::read() @ 0x000000002c8242f9 24. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000002de6d77a 25. ./build_docker/./src/Processors/ISource.cpp:0: DB::ISource::work() @ 0x000000002d3290a1 26. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 27. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 28. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 29. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 30. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 31. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 2025.09.09 15:07:01.289734 [ 20350 ] {9deafa97-ec7c-46a1-a336-c1e0e968665b} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=9, jobs=0): (while reading column key_column): (while reading from part /var/lib/clickhouse/store/cab/cabf9a66-80e2-4148-8335-3c53187f5a8a/all_1_1_0/ in table database_for_dict.table_for_dict (cabf9a66-80e2-4148-8335-3c53187f5a8a) located on disk default of type local, from mark 0 with max_rows_to_read = 1): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder): while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45606) (comment: 01542_dictionary_load_exception_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af80b71 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80746 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000266005a2 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000265fffb4 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:1197: ? @ 0x00000000265fd4e7 9. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:62: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x00000000265e6fbd 10. ./contrib/llvm-project/libcxx/include/future:1123: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x00000000265e7bb3 11. DB::ReadBuffer::next() @ 0x000000000b528aeb 12. ./src/IO/ReadBuffer.h:0: DB::CompressedReadBufferBase::readCompressedDataBlockForAsynchronous(unsigned long&, unsigned long&) @ 0x0000000027760e7f 13. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:110: DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x0000000027764c41 14. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:222: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x0000000027b97730 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 @ 0x0000000027aa00db 16. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:0: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x000000002c7b254b 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7eb79e 18. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:118: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7c9d8a 19. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x000000002c7e0473 20. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x000000002c7dbec3 21. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:0: DB::MergeTreeReadTask::read(DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002c82d05b 22. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:53: DB::MergeTreeInOrderSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&, DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002dea5374 23. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:0: DB::MergeTreeSelectProcessor::read() @ 0x000000002c8242f9 24. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000002de6d77a 25. ./build_docker/./src/Processors/ISource.cpp:0: DB::ISource::work() @ 0x000000002d3290a1 26. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 27. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 28. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 29. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 30. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 31. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 2025.09.09 15:07:01.298381 [ 20350 ] {9deafa97-ec7c-46a1-a336-c1e0e968665b} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=9, jobs=0): (while reading column key_column): (while reading from part /var/lib/clickhouse/store/cab/cabf9a66-80e2-4148-8335-3c53187f5a8a/all_1_1_0/ in table database_for_dict.table_for_dict (cabf9a66-80e2-4148-8335-3c53187f5a8a) located on disk default of type local, from mark 0 with max_rows_to_read = 1): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder): while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af80b71 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80746 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000266005a2 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000265fffb4 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:1197: ? @ 0x00000000265fd4e7 9. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:62: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x00000000265e6fbd 10. ./contrib/llvm-project/libcxx/include/future:1123: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x00000000265e7bb3 11. DB::ReadBuffer::next() @ 0x000000000b528aeb 12. ./src/IO/ReadBuffer.h:0: DB::CompressedReadBufferBase::readCompressedDataBlockForAsynchronous(unsigned long&, unsigned long&) @ 0x0000000027760e7f 13. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:110: DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x0000000027764c41 14. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:222: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x0000000027b97730 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 @ 0x0000000027aa00db 16. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:0: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x000000002c7b254b 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7eb79e 18. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:118: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7c9d8a 19. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x000000002c7e0473 20. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x000000002c7dbec3 21. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:0: DB::MergeTreeReadTask::read(DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002c82d05b 22. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:53: DB::MergeTreeInOrderSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&, DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002dea5374 23. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:0: DB::MergeTreeSelectProcessor::read() @ 0x000000002c8242f9 24. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000002de6d77a 25. ./build_docker/./src/Processors/ISource.cpp:0: DB::ISource::work() @ 0x000000002d3290a1 26. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 27. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 28. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 29. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 30. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 31. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 2025.09.09 15:07:01.355946 [ 20881 ] {0be1bb01-c6e6-4379-9c37-51d5c2934613} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=9, jobs=0): (while reading column key_column): (while reading from part /var/lib/clickhouse/store/cab/cabf9a66-80e2-4148-8335-3c53187f5a8a/all_1_1_0/ in table database_for_dict.table_for_dict (cabf9a66-80e2-4148-8335-3c53187f5a8a) located on disk default of type local, from mark 0 with max_rows_to_read = 1): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder): while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45602) (comment: 01542_dictionary_load_exception_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af80b71 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80746 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000266005a2 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000265fffb4 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:1197: ? @ 0x00000000265fd4e7 9. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:62: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x00000000265e6fbd 10. ./contrib/llvm-project/libcxx/include/future:1123: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x00000000265e7bb3 11. DB::ReadBuffer::next() @ 0x000000000b528aeb 12. ./src/IO/ReadBuffer.h:0: DB::CompressedReadBufferBase::readCompressedDataBlockForAsynchronous(unsigned long&, unsigned long&) @ 0x0000000027760e7f 13. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:110: DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x0000000027764c41 14. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:222: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x0000000027b97730 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 @ 0x0000000027aa00db 16. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:0: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x000000002c7b254b 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7eb79e 18. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:118: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7c9d8a 19. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x000000002c7e0473 20. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x000000002c7dbec3 21. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:0: DB::MergeTreeReadTask::read(DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002c82d05b 22. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:53: DB::MergeTreeInOrderSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&, DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002dea5374 23. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:0: DB::MergeTreeSelectProcessor::read() @ 0x000000002c8242f9 24. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000002de6d77a 25. ./build_docker/./src/Processors/ISource.cpp:0: DB::ISource::work() @ 0x000000002d3290a1 26. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 27. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 28. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 29. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 30. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 31. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 2025.09.09 15:07:01.357655 [ 20881 ] {0be1bb01-c6e6-4379-9c37-51d5c2934613} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=9, jobs=0): (while reading column key_column): (while reading from part /var/lib/clickhouse/store/cab/cabf9a66-80e2-4148-8335-3c53187f5a8a/all_1_1_0/ in table database_for_dict.table_for_dict (cabf9a66-80e2-4148-8335-3c53187f5a8a) located on disk default of type local, from mark 0 with max_rows_to_read = 1): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder): while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af80b71 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80746 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000266005a2 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000265fffb4 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:1197: ? @ 0x00000000265fd4e7 9. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:62: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x00000000265e6fbd 10. ./contrib/llvm-project/libcxx/include/future:1123: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x00000000265e7bb3 11. DB::ReadBuffer::next() @ 0x000000000b528aeb 12. ./src/IO/ReadBuffer.h:0: DB::CompressedReadBufferBase::readCompressedDataBlockForAsynchronous(unsigned long&, unsigned long&) @ 0x0000000027760e7f 13. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:110: DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x0000000027764c41 14. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:222: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x0000000027b97730 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 @ 0x0000000027aa00db 16. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:0: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x000000002c7b254b 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7eb79e 18. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:118: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7c9d8a 19. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x000000002c7e0473 20. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x000000002c7dbec3 21. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:0: DB::MergeTreeReadTask::read(DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002c82d05b 22. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:53: DB::MergeTreeInOrderSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&, DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002dea5374 23. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:0: DB::MergeTreeSelectProcessor::read() @ 0x000000002c8242f9 24. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000002de6d77a 25. ./build_docker/./src/Processors/ISource.cpp:0: DB::ISource::work() @ 0x000000002d3290a1 26. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 27. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 28. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 29. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 30. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 31. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 2025.09.09 15:07:01.492503 [ 20351 ] {2ed0b72a-0343-4aab-b9e0-95aa54d88ef8} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=9, jobs=0): (while reading column key_column): (while reading from part /var/lib/clickhouse/store/cab/cabf9a66-80e2-4148-8335-3c53187f5a8a/all_1_1_0/ in table database_for_dict.table_for_dict (cabf9a66-80e2-4148-8335-3c53187f5a8a) located on disk default of type local, from mark 0 with max_rows_to_read = 1): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder): while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45622) (comment: 01542_dictionary_load_exception_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af80b71 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80746 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000266005a2 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000265fffb4 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:1197: ? @ 0x00000000265fd4e7 9. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:62: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x00000000265e6fbd 10. ./contrib/llvm-project/libcxx/include/future:1123: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x00000000265e7bb3 11. DB::ReadBuffer::next() @ 0x000000000b528aeb 12. ./src/IO/ReadBuffer.h:0: DB::CompressedReadBufferBase::readCompressedDataBlockForAsynchronous(unsigned long&, unsigned long&) @ 0x0000000027760e7f 13. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:110: DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x0000000027764c41 14. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:222: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x0000000027b97730 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 @ 0x0000000027aa00db 16. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:0: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x000000002c7b254b 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7eb79e 18. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:118: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7c9d8a 19. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x000000002c7e0473 20. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x000000002c7dbec3 21. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:0: DB::MergeTreeReadTask::read(DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002c82d05b 22. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:53: DB::MergeTreeInOrderSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&, DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002dea5374 23. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:0: DB::MergeTreeSelectProcessor::read() @ 0x000000002c8242f9 24. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000002de6d77a 25. ./build_docker/./src/Processors/ISource.cpp:0: DB::ISource::work() @ 0x000000002d3290a1 26. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 27. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 28. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 29. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 30. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 31. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 2025.09.09 15:07:01.506395 [ 20351 ] {2ed0b72a-0343-4aab-b9e0-95aa54d88ef8} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=9, jobs=0): (while reading column key_column): (while reading from part /var/lib/clickhouse/store/cab/cabf9a66-80e2-4148-8335-3c53187f5a8a/all_1_1_0/ in table database_for_dict.table_for_dict (cabf9a66-80e2-4148-8335-3c53187f5a8a) located on disk default of type local, from mark 0 with max_rows_to_read = 1): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder): while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af80b71 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80746 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000266005a2 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000265fffb4 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:1197: ? @ 0x00000000265fd4e7 9. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:62: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x00000000265e6fbd 10. ./contrib/llvm-project/libcxx/include/future:1123: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x00000000265e7bb3 11. DB::ReadBuffer::next() @ 0x000000000b528aeb 12. ./src/IO/ReadBuffer.h:0: DB::CompressedReadBufferBase::readCompressedDataBlockForAsynchronous(unsigned long&, unsigned long&) @ 0x0000000027760e7f 13. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:110: DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x0000000027764c41 14. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:222: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x0000000027b97730 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 @ 0x0000000027aa00db 16. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:0: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x000000002c7b254b 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7eb79e 18. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:118: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7c9d8a 19. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x000000002c7e0473 20. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x000000002c7dbec3 21. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:0: DB::MergeTreeReadTask::read(DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002c82d05b 22. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:53: DB::MergeTreeInOrderSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&, DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002dea5374 23. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:0: DB::MergeTreeSelectProcessor::read() @ 0x000000002c8242f9 24. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000002de6d77a 25. ./build_docker/./src/Processors/ISource.cpp:0: DB::ISource::work() @ 0x000000002d3290a1 26. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 27. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 28. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 29. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 30. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 31. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 2025.09.09 15:07:01.515139 [ 20397 ] {fcf06768-444c-4d77-9aed-fb658d6fc692} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=9, jobs=0): (while reading column key_column): (while reading from part /var/lib/clickhouse/store/cab/cabf9a66-80e2-4148-8335-3c53187f5a8a/all_1_1_0/ in table database_for_dict.table_for_dict (cabf9a66-80e2-4148-8335-3c53187f5a8a) located on disk default of type local, from mark 0 with max_rows_to_read = 1): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder): while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45626) (comment: 01542_dictionary_load_exception_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af80b71 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80746 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000266005a2 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000265fffb4 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:1197: ? @ 0x00000000265fd4e7 9. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:62: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x00000000265e6fbd 10. ./contrib/llvm-project/libcxx/include/future:1123: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x00000000265e7bb3 11. DB::ReadBuffer::next() @ 0x000000000b528aeb 12. ./src/IO/ReadBuffer.h:0: DB::CompressedReadBufferBase::readCompressedDataBlockForAsynchronous(unsigned long&, unsigned long&) @ 0x0000000027760e7f 13. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:110: DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x0000000027764c41 14. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:222: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x0000000027b97730 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 @ 0x0000000027aa00db 16. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:0: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x000000002c7b254b 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7eb79e 18. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:118: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7c9d8a 19. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x000000002c7e0473 20. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x000000002c7dbec3 21. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:0: DB::MergeTreeReadTask::read(DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002c82d05b 22. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:53: DB::MergeTreeInOrderSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&, DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002dea5374 23. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:0: DB::MergeTreeSelectProcessor::read() @ 0x000000002c8242f9 24. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000002de6d77a 25. ./build_docker/./src/Processors/ISource.cpp:0: DB::ISource::work() @ 0x000000002d3290a1 26. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 27. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 28. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 29. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 30. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 31. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 2025.09.09 15:07:01.517443 [ 20397 ] {fcf06768-444c-4d77-9aed-fb658d6fc692} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=9, jobs=0): (while reading column key_column): (while reading from part /var/lib/clickhouse/store/cab/cabf9a66-80e2-4148-8335-3c53187f5a8a/all_1_1_0/ in table database_for_dict.table_for_dict (cabf9a66-80e2-4148-8335-3c53187f5a8a) located on disk default of type local, from mark 0 with max_rows_to_read = 1): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder): while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af80b71 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80746 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000266005a2 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000265fffb4 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:1197: ? @ 0x00000000265fd4e7 9. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:62: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x00000000265e6fbd 10. ./contrib/llvm-project/libcxx/include/future:1123: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x00000000265e7bb3 11. DB::ReadBuffer::next() @ 0x000000000b528aeb 12. ./src/IO/ReadBuffer.h:0: DB::CompressedReadBufferBase::readCompressedDataBlockForAsynchronous(unsigned long&, unsigned long&) @ 0x0000000027760e7f 13. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:110: DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x0000000027764c41 14. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:222: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x0000000027b97730 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 @ 0x0000000027aa00db 16. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:0: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x000000002c7b254b 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7eb79e 18. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:118: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7c9d8a 19. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x000000002c7e0473 20. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x000000002c7dbec3 21. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:0: DB::MergeTreeReadTask::read(DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002c82d05b 22. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:53: DB::MergeTreeInOrderSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&, DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002dea5374 23. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:0: DB::MergeTreeSelectProcessor::read() @ 0x000000002c8242f9 24. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000002de6d77a 25. ./build_docker/./src/Processors/ISource.cpp:0: DB::ISource::work() @ 0x000000002d3290a1 26. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 27. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 28. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 29. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 30. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 31. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 2025.09.09 15:07:01.527496 [ 2892 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:07:01.529316 [ 2884 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:07:01.620732 [ 2868 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:07:01.687007 [ 20338 ] {c2675b82-59ec-4429-9287-dc75a2a6ef23} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=9, jobs=0): (while reading column key_column): (while reading from part /var/lib/clickhouse/store/cab/cabf9a66-80e2-4148-8335-3c53187f5a8a/all_1_1_0/ in table database_for_dict.table_for_dict (cabf9a66-80e2-4148-8335-3c53187f5a8a) located on disk default of type local, from mark 0 with max_rows_to_read = 1): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder): while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45636) (comment: 01542_dictionary_load_exception_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af80b71 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80746 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000266005a2 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000265fffb4 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:1197: ? @ 0x00000000265fd4e7 9. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:62: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x00000000265e6fbd 10. ./contrib/llvm-project/libcxx/include/future:1123: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x00000000265e7bb3 11. DB::ReadBuffer::next() @ 0x000000000b528aeb 12. ./src/IO/ReadBuffer.h:0: DB::CompressedReadBufferBase::readCompressedDataBlockForAsynchronous(unsigned long&, unsigned long&) @ 0x0000000027760e7f 13. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:110: DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x0000000027764c41 14. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:222: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x0000000027b97730 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 @ 0x0000000027aa00db 16. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:0: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x000000002c7b254b 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7eb79e 18. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:118: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7c9d8a 19. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x000000002c7e0473 20. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x000000002c7dbec3 21. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:0: DB::MergeTreeReadTask::read(DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002c82d05b 22. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:53: DB::MergeTreeInOrderSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&, DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002dea5374 23. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:0: DB::MergeTreeSelectProcessor::read() @ 0x000000002c8242f9 24. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000002de6d77a 25. ./build_docker/./src/Processors/ISource.cpp:0: DB::ISource::work() @ 0x000000002d3290a1 26. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 27. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 28. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 29. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 30. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 31. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 2025.09.09 15:07:01.694314 [ 20338 ] {c2675b82-59ec-4429-9287-dc75a2a6ef23} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=9, jobs=0): (while reading column key_column): (while reading from part /var/lib/clickhouse/store/cab/cabf9a66-80e2-4148-8335-3c53187f5a8a/all_1_1_0/ in table database_for_dict.table_for_dict (cabf9a66-80e2-4148-8335-3c53187f5a8a) located on disk default of type local, from mark 0 with max_rows_to_read = 1): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder): while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af80b71 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80746 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000266005a2 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000265fffb4 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:1197: ? @ 0x00000000265fd4e7 9. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:62: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x00000000265e6fbd 10. ./contrib/llvm-project/libcxx/include/future:1123: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x00000000265e7bb3 11. DB::ReadBuffer::next() @ 0x000000000b528aeb 12. ./src/IO/ReadBuffer.h:0: DB::CompressedReadBufferBase::readCompressedDataBlockForAsynchronous(unsigned long&, unsigned long&) @ 0x0000000027760e7f 13. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:110: DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x0000000027764c41 14. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:222: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x0000000027b97730 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 @ 0x0000000027aa00db 16. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:0: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x000000002c7b254b 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7eb79e 18. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:118: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7c9d8a 19. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x000000002c7e0473 20. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x000000002c7dbec3 21. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:0: DB::MergeTreeReadTask::read(DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002c82d05b 22. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:53: DB::MergeTreeInOrderSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&, DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002dea5374 23. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:0: DB::MergeTreeSelectProcessor::read() @ 0x000000002c8242f9 24. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000002de6d77a 25. ./build_docker/./src/Processors/ISource.cpp:0: DB::ISource::work() @ 0x000000002d3290a1 26. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 27. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 28. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 29. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 30. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 31. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 2025.09.09 15:07:01.839237 [ 20881 ] {11ca6d7a-e9b6-4ea4-888f-a53b1dc97ede} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=9, jobs=0): (while reading column key_column): (while reading from part /var/lib/clickhouse/store/cab/cabf9a66-80e2-4148-8335-3c53187f5a8a/all_1_1_0/ in table database_for_dict.table_for_dict (cabf9a66-80e2-4148-8335-3c53187f5a8a) located on disk default of type local, from mark 0 with max_rows_to_read = 1): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder): while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45666) (comment: 01542_dictionary_load_exception_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af80b71 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80746 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000266005a2 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000265fffb4 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:1197: ? @ 0x00000000265fd4e7 9. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:62: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x00000000265e6fbd 10. ./contrib/llvm-project/libcxx/include/future:1123: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x00000000265e7bb3 11. DB::ReadBuffer::next() @ 0x000000000b528aeb 12. ./src/IO/ReadBuffer.h:0: DB::CompressedReadBufferBase::readCompressedDataBlockForAsynchronous(unsigned long&, unsigned long&) @ 0x0000000027760e7f 13. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:110: DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x0000000027764c41 14. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:222: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x0000000027b97730 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 @ 0x0000000027aa00db 16. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:0: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x000000002c7b254b 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7eb79e 18. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:118: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7c9d8a 19. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x000000002c7e0473 20. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x000000002c7dbec3 21. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:0: DB::MergeTreeReadTask::read(DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002c82d05b 22. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:53: DB::MergeTreeInOrderSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&, DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002dea5374 23. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:0: DB::MergeTreeSelectProcessor::read() @ 0x000000002c8242f9 24. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000002de6d77a 25. ./build_docker/./src/Processors/ISource.cpp:0: DB::ISource::work() @ 0x000000002d3290a1 26. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 27. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 28. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 29. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 30. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 31. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 2025.09.09 15:07:01.866846 [ 20881 ] {11ca6d7a-e9b6-4ea4-888f-a53b1dc97ede} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=9, jobs=0): (while reading column key_column): (while reading from part /var/lib/clickhouse/store/cab/cabf9a66-80e2-4148-8335-3c53187f5a8a/all_1_1_0/ in table database_for_dict.table_for_dict (cabf9a66-80e2-4148-8335-3c53187f5a8a) located on disk default of type local, from mark 0 with max_rows_to_read = 1): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder): while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af80b71 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80746 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000266005a2 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000265fffb4 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:1197: ? @ 0x00000000265fd4e7 9. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:62: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x00000000265e6fbd 10. ./contrib/llvm-project/libcxx/include/future:1123: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x00000000265e7bb3 11. DB::ReadBuffer::next() @ 0x000000000b528aeb 12. ./src/IO/ReadBuffer.h:0: DB::CompressedReadBufferBase::readCompressedDataBlockForAsynchronous(unsigned long&, unsigned long&) @ 0x0000000027760e7f 13. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:110: DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x0000000027764c41 14. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:222: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x0000000027b97730 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 @ 0x0000000027aa00db 16. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:0: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x000000002c7b254b 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7eb79e 18. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:118: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7c9d8a 19. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x000000002c7e0473 20. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x000000002c7dbec3 21. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:0: DB::MergeTreeReadTask::read(DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002c82d05b 22. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:53: DB::MergeTreeInOrderSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&, DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002dea5374 23. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:0: DB::MergeTreeSelectProcessor::read() @ 0x000000002c8242f9 24. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000002de6d77a 25. ./build_docker/./src/Processors/ISource.cpp:0: DB::ISource::work() @ 0x000000002d3290a1 26. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 27. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 28. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 29. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 30. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 31. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 2025.09.09 15:07:01.908369 [ 2688 ] {72a35ec4-1167-4034-b15b-10a6c28d3e16} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=9, jobs=0): (while reading column key_column): (while reading from part /var/lib/clickhouse/store/cab/cabf9a66-80e2-4148-8335-3c53187f5a8a/all_1_1_0/ in table database_for_dict.table_for_dict (cabf9a66-80e2-4148-8335-3c53187f5a8a) located on disk default of type local, from mark 0 with max_rows_to_read = 1): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder): while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45632) (comment: 01542_dictionary_load_exception_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af80b71 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80746 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000266005a2 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000265fffb4 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:1197: ? @ 0x00000000265fd4e7 9. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:62: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x00000000265e6fbd 10. ./contrib/llvm-project/libcxx/include/future:1123: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x00000000265e7bb3 11. DB::ReadBuffer::next() @ 0x000000000b528aeb 12. ./src/IO/ReadBuffer.h:0: DB::CompressedReadBufferBase::readCompressedDataBlockForAsynchronous(unsigned long&, unsigned long&) @ 0x0000000027760e7f 13. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:110: DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x0000000027764c41 14. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:222: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x0000000027b97730 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 @ 0x0000000027aa00db 16. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:0: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x000000002c7b254b 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7eb79e 18. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:118: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7c9d8a 19. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x000000002c7e0473 20. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x000000002c7dbec3 21. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:0: DB::MergeTreeReadTask::read(DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002c82d05b 22. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:53: DB::MergeTreeInOrderSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&, DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002dea5374 23. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:0: DB::MergeTreeSelectProcessor::read() @ 0x000000002c8242f9 24. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000002de6d77a 25. ./build_docker/./src/Processors/ISource.cpp:0: DB::ISource::work() @ 0x000000002d3290a1 26. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 27. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 28. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 29. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 30. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 31. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 2025.09.09 15:07:01.924520 [ 2688 ] {72a35ec4-1167-4034-b15b-10a6c28d3e16} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=9, jobs=0): (while reading column key_column): (while reading from part /var/lib/clickhouse/store/cab/cabf9a66-80e2-4148-8335-3c53187f5a8a/all_1_1_0/ in table database_for_dict.table_for_dict (cabf9a66-80e2-4148-8335-3c53187f5a8a) located on disk default of type local, from mark 0 with max_rows_to_read = 1): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder): while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af80b71 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80746 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000266005a2 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000265fffb4 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:1197: ? @ 0x00000000265fd4e7 9. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:62: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x00000000265e6fbd 10. ./contrib/llvm-project/libcxx/include/future:1123: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x00000000265e7bb3 11. DB::ReadBuffer::next() @ 0x000000000b528aeb 12. ./src/IO/ReadBuffer.h:0: DB::CompressedReadBufferBase::readCompressedDataBlockForAsynchronous(unsigned long&, unsigned long&) @ 0x0000000027760e7f 13. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:110: DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x0000000027764c41 14. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:222: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x0000000027b97730 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 @ 0x0000000027aa00db 16. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:0: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x000000002c7b254b 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7eb79e 18. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:118: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7c9d8a 19. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x000000002c7e0473 20. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x000000002c7dbec3 21. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:0: DB::MergeTreeReadTask::read(DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002c82d05b 22. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:53: DB::MergeTreeInOrderSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&, DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002dea5374 23. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:0: DB::MergeTreeSelectProcessor::read() @ 0x000000002c8242f9 24. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000002de6d77a 25. ./build_docker/./src/Processors/ISource.cpp:0: DB::ISource::work() @ 0x000000002d3290a1 26. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 27. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 28. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 29. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 30. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 31. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 2025.09.09 15:07:02.022004 [ 20397 ] {d6006ae4-819c-4b98-ad2e-ef167be08e22} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=9, jobs=0): (while reading column key_column): (while reading from part /var/lib/clickhouse/store/cab/cabf9a66-80e2-4148-8335-3c53187f5a8a/all_1_1_0/ in table database_for_dict.table_for_dict (cabf9a66-80e2-4148-8335-3c53187f5a8a) located on disk default of type local, from mark 0 with max_rows_to_read = 1): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder): while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45670) (comment: 01542_dictionary_load_exception_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af80b71 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80746 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000266005a2 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000265fffb4 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:1197: ? @ 0x00000000265fd4e7 9. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:62: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x00000000265e6fbd 10. ./contrib/llvm-project/libcxx/include/future:1123: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x00000000265e7bb3 11. DB::ReadBuffer::next() @ 0x000000000b528aeb 12. ./src/IO/ReadBuffer.h:0: DB::CompressedReadBufferBase::readCompressedDataBlockForAsynchronous(unsigned long&, unsigned long&) @ 0x0000000027760e7f 13. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:110: DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x0000000027764c41 14. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:222: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x0000000027b97730 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 @ 0x0000000027aa00db 16. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:0: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x000000002c7b254b 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7eb79e 18. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:118: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7c9d8a 19. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x000000002c7e0473 20. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x000000002c7dbec3 21. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:0: DB::MergeTreeReadTask::read(DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002c82d05b 22. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:53: DB::MergeTreeInOrderSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&, DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002dea5374 23. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:0: DB::MergeTreeSelectProcessor::read() @ 0x000000002c8242f9 24. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000002de6d77a 25. ./build_docker/./src/Processors/ISource.cpp:0: DB::ISource::work() @ 0x000000002d3290a1 26. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 27. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 28. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 29. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 30. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 31. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 2025.09.09 15:07:02.024450 [ 20397 ] {d6006ae4-819c-4b98-ad2e-ef167be08e22} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=9, jobs=0): (while reading column key_column): (while reading from part /var/lib/clickhouse/store/cab/cabf9a66-80e2-4148-8335-3c53187f5a8a/all_1_1_0/ in table database_for_dict.table_for_dict (cabf9a66-80e2-4148-8335-3c53187f5a8a) located on disk default of type local, from mark 0 with max_rows_to_read = 1): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder): while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af80b71 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80746 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000266005a2 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000265fffb4 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:1197: ? @ 0x00000000265fd4e7 9. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:62: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x00000000265e6fbd 10. ./contrib/llvm-project/libcxx/include/future:1123: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x00000000265e7bb3 11. DB::ReadBuffer::next() @ 0x000000000b528aeb 12. ./src/IO/ReadBuffer.h:0: DB::CompressedReadBufferBase::readCompressedDataBlockForAsynchronous(unsigned long&, unsigned long&) @ 0x0000000027760e7f 13. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:110: DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x0000000027764c41 14. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:222: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x0000000027b97730 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 @ 0x0000000027aa00db 16. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:0: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x000000002c7b254b 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7eb79e 18. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:118: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7c9d8a 19. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x000000002c7e0473 20. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x000000002c7dbec3 21. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:0: DB::MergeTreeReadTask::read(DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002c82d05b 22. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:53: DB::MergeTreeInOrderSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&, DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002dea5374 23. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:0: DB::MergeTreeSelectProcessor::read() @ 0x000000002c8242f9 24. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000002de6d77a 25. ./build_docker/./src/Processors/ISource.cpp:0: DB::ISource::work() @ 0x000000002d3290a1 26. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 27. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 28. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 29. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 30. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 31. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 2025.09.09 15:07:02.075108 [ 20350 ] {e23af5ab-cfda-452d-8d3a-7b1e132aa2dd} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=9, jobs=0): (while reading column key_column): (while reading from part /var/lib/clickhouse/store/cab/cabf9a66-80e2-4148-8335-3c53187f5a8a/all_1_1_0/ in table database_for_dict.table_for_dict (cabf9a66-80e2-4148-8335-3c53187f5a8a) located on disk default of type local, from mark 0 with max_rows_to_read = 1): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder): while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45680) (comment: 01542_dictionary_load_exception_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af80b71 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80746 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000266005a2 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000265fffb4 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:1197: ? @ 0x00000000265fd4e7 9. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:62: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x00000000265e6fbd 10. ./contrib/llvm-project/libcxx/include/future:1123: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x00000000265e7bb3 11. DB::ReadBuffer::next() @ 0x000000000b528aeb 12. ./src/IO/ReadBuffer.h:0: DB::CompressedReadBufferBase::readCompressedDataBlockForAsynchronous(unsigned long&, unsigned long&) @ 0x0000000027760e7f 13. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:110: DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x0000000027764c41 14. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:222: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x0000000027b97730 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 @ 0x0000000027aa00db 16. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:0: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x000000002c7b254b 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7eb79e 18. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:118: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7c9d8a 19. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x000000002c7e0473 20. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x000000002c7dbec3 21. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:0: DB::MergeTreeReadTask::read(DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002c82d05b 22. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:53: DB::MergeTreeInOrderSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&, DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002dea5374 23. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:0: DB::MergeTreeSelectProcessor::read() @ 0x000000002c8242f9 24. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000002de6d77a 25. ./build_docker/./src/Processors/ISource.cpp:0: DB::ISource::work() @ 0x000000002d3290a1 26. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 27. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 28. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 29. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 30. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 31. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 2025.09.09 15:07:02.077429 [ 20350 ] {e23af5ab-cfda-452d-8d3a-7b1e132aa2dd} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=9, jobs=0): (while reading column key_column): (while reading from part /var/lib/clickhouse/store/cab/cabf9a66-80e2-4148-8335-3c53187f5a8a/all_1_1_0/ in table database_for_dict.table_for_dict (cabf9a66-80e2-4148-8335-3c53187f5a8a) located on disk default of type local, from mark 0 with max_rows_to_read = 1): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder): while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af80b71 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80746 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000266005a2 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000265fffb4 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:1197: ? @ 0x00000000265fd4e7 9. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:62: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x00000000265e6fbd 10. ./contrib/llvm-project/libcxx/include/future:1123: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x00000000265e7bb3 11. DB::ReadBuffer::next() @ 0x000000000b528aeb 12. ./src/IO/ReadBuffer.h:0: DB::CompressedReadBufferBase::readCompressedDataBlockForAsynchronous(unsigned long&, unsigned long&) @ 0x0000000027760e7f 13. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:110: DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x0000000027764c41 14. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:222: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x0000000027b97730 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 @ 0x0000000027aa00db 16. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:0: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x000000002c7b254b 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7eb79e 18. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:118: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7c9d8a 19. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x000000002c7e0473 20. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x000000002c7dbec3 21. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:0: DB::MergeTreeReadTask::read(DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002c82d05b 22. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:53: DB::MergeTreeInOrderSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&, DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002dea5374 23. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:0: DB::MergeTreeSelectProcessor::read() @ 0x000000002c8242f9 24. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000002de6d77a 25. ./build_docker/./src/Processors/ISource.cpp:0: DB::ISource::work() @ 0x000000002d3290a1 26. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 27. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 28. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 29. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 30. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 31. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 2025.09.09 15:07:02.122296 [ 20351 ] {fbe80f1e-4510-450c-a750-8e4f58c5259d} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=9, jobs=0): (while reading column key_column): (while reading from part /var/lib/clickhouse/store/cab/cabf9a66-80e2-4148-8335-3c53187f5a8a/all_1_1_0/ in table database_for_dict.table_for_dict (cabf9a66-80e2-4148-8335-3c53187f5a8a) located on disk default of type local, from mark 0 with max_rows_to_read = 1): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder): while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45692) (comment: 01542_dictionary_load_exception_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af80b71 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80746 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000266005a2 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000265fffb4 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:1197: ? @ 0x00000000265fd4e7 9. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:62: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x00000000265e6fbd 10. ./contrib/llvm-project/libcxx/include/future:1123: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x00000000265e7bb3 11. DB::ReadBuffer::next() @ 0x000000000b528aeb 12. ./src/IO/ReadBuffer.h:0: DB::CompressedReadBufferBase::readCompressedDataBlockForAsynchronous(unsigned long&, unsigned long&) @ 0x0000000027760e7f 13. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:110: DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x0000000027764c41 14. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:222: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x0000000027b97730 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 @ 0x0000000027aa00db 16. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:0: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x000000002c7b254b 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7eb79e 18. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:118: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7c9d8a 19. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x000000002c7e0473 20. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x000000002c7dbec3 21. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:0: DB::MergeTreeReadTask::read(DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002c82d05b 22. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:53: DB::MergeTreeInOrderSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&, DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002dea5374 23. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:0: DB::MergeTreeSelectProcessor::read() @ 0x000000002c8242f9 24. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000002de6d77a 25. ./build_docker/./src/Processors/ISource.cpp:0: DB::ISource::work() @ 0x000000002d3290a1 26. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 27. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 28. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 29. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 30. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 31. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 2025.09.09 15:07:02.136465 [ 20351 ] {fbe80f1e-4510-450c-a750-8e4f58c5259d} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=9, jobs=0): (while reading column key_column): (while reading from part /var/lib/clickhouse/store/cab/cabf9a66-80e2-4148-8335-3c53187f5a8a/all_1_1_0/ in table database_for_dict.table_for_dict (cabf9a66-80e2-4148-8335-3c53187f5a8a) located on disk default of type local, from mark 0 with max_rows_to_read = 1): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder): while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af80b71 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80746 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000266005a2 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000265fffb4 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:1197: ? @ 0x00000000265fd4e7 9. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:62: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x00000000265e6fbd 10. ./contrib/llvm-project/libcxx/include/future:1123: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x00000000265e7bb3 11. DB::ReadBuffer::next() @ 0x000000000b528aeb 12. ./src/IO/ReadBuffer.h:0: DB::CompressedReadBufferBase::readCompressedDataBlockForAsynchronous(unsigned long&, unsigned long&) @ 0x0000000027760e7f 13. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:110: DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x0000000027764c41 14. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:222: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x0000000027b97730 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 @ 0x0000000027aa00db 16. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:0: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x000000002c7b254b 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7eb79e 18. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:118: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7c9d8a 19. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x000000002c7e0473 20. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x000000002c7dbec3 21. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:0: DB::MergeTreeReadTask::read(DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002c82d05b 22. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:53: DB::MergeTreeInOrderSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&, DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002dea5374 23. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:0: DB::MergeTreeSelectProcessor::read() @ 0x000000002c8242f9 24. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000002de6d77a 25. ./build_docker/./src/Processors/ISource.cpp:0: DB::ISource::work() @ 0x000000002d3290a1 26. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 27. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 28. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 29. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 30. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 31. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 2025.09.09 15:07:02.168004 [ 2923 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:07:02.189953 [ 20343 ] {84fbefc5-37ba-4c5e-919d-cdc6d77a73b4} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=9, jobs=0): (while reading column key_column): (while reading from part /var/lib/clickhouse/store/cab/cabf9a66-80e2-4148-8335-3c53187f5a8a/all_1_1_0/ in table database_for_dict.table_for_dict (cabf9a66-80e2-4148-8335-3c53187f5a8a) located on disk default of type local, from mark 0 with max_rows_to_read = 1): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder): while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45694) (comment: 01542_dictionary_load_exception_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af80b71 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80746 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000266005a2 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000265fffb4 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:1197: ? @ 0x00000000265fd4e7 9. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:62: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x00000000265e6fbd 10. ./contrib/llvm-project/libcxx/include/future:1123: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x00000000265e7bb3 11. DB::ReadBuffer::next() @ 0x000000000b528aeb 12. ./src/IO/ReadBuffer.h:0: DB::CompressedReadBufferBase::readCompressedDataBlockForAsynchronous(unsigned long&, unsigned long&) @ 0x0000000027760e7f 13. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:110: DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x0000000027764c41 14. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:222: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x0000000027b97730 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 @ 0x0000000027aa00db 16. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:0: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x000000002c7b254b 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7eb79e 18. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:118: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7c9d8a 19. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x000000002c7e0473 20. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x000000002c7dbec3 21. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:0: DB::MergeTreeReadTask::read(DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002c82d05b 22. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:53: DB::MergeTreeInOrderSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&, DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002dea5374 23. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:0: DB::MergeTreeSelectProcessor::read() @ 0x000000002c8242f9 24. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000002de6d77a 25. ./build_docker/./src/Processors/ISource.cpp:0: DB::ISource::work() @ 0x000000002d3290a1 26. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 27. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 28. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 29. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 30. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 31. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 2025.09.09 15:07:02.198657 [ 20343 ] {84fbefc5-37ba-4c5e-919d-cdc6d77a73b4} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=9, jobs=0): (while reading column key_column): (while reading from part /var/lib/clickhouse/store/cab/cabf9a66-80e2-4148-8335-3c53187f5a8a/all_1_1_0/ in table database_for_dict.table_for_dict (cabf9a66-80e2-4148-8335-3c53187f5a8a) located on disk default of type local, from mark 0 with max_rows_to_read = 1): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder): while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af80b71 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80746 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000266005a2 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000265fffb4 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:1197: ? @ 0x00000000265fd4e7 9. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:62: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x00000000265e6fbd 10. ./contrib/llvm-project/libcxx/include/future:1123: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x00000000265e7bb3 11. DB::ReadBuffer::next() @ 0x000000000b528aeb 12. ./src/IO/ReadBuffer.h:0: DB::CompressedReadBufferBase::readCompressedDataBlockForAsynchronous(unsigned long&, unsigned long&) @ 0x0000000027760e7f 13. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:110: DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x0000000027764c41 14. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:222: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x0000000027b97730 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 @ 0x0000000027aa00db 16. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:0: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x000000002c7b254b 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7eb79e 18. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:118: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7c9d8a 19. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x000000002c7e0473 20. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x000000002c7dbec3 21. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:0: DB::MergeTreeReadTask::read(DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002c82d05b 22. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:53: DB::MergeTreeInOrderSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&, DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002dea5374 23. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:0: DB::MergeTreeSelectProcessor::read() @ 0x000000002c8242f9 24. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000002de6d77a 25. ./build_docker/./src/Processors/ISource.cpp:0: DB::ISource::work() @ 0x000000002d3290a1 26. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 27. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 28. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 29. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 30. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 31. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 2025.09.09 15:07:02.267357 [ 5774 ] {} ExternalDictionariesLoader: Could not load external dictionary 'b9456353-118f-4e69-ac1b-88d4f6a6e618', next update is scheduled at 2025-09-09 15:07: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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:07:02.324453 [ 20355 ] {fbba5730-8ddc-43b9-b7d7-61a836e6e4d3} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45708) (comment: 01542_dictionary_load_exception_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:02.326446 [ 20355 ] {fbba5730-8ddc-43b9-b7d7-61a836e6e4d3} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:02.335124 [ 20338 ] {d2c59780-6d98-45af-aa14-2cdcaea1ccfa} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45710) (comment: 01542_dictionary_load_exception_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:02.337318 [ 20338 ] {d2c59780-6d98-45af-aa14-2cdcaea1ccfa} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:02.386840 [ 20338 ] {} ServerErrorHandler: Code: 210. DB::NetException: Connection reset by peer, while reading from socket (peer: [::1]:45710, 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 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&&) @ 0x000000001b0b7a5f 3. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:83: DB::ReadBufferFromPocoSocketBase::socketReceiveBytesImpl(char*, unsigned long) @ 0x000000001b0b6042 4. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:107: DB::ReadBufferFromPocoSocketBase::nextImpl() @ 0x000000001b0b6b84 5. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:103: DB::ReadBufferFromPocoSocketChunked::nextImpl() @ 0x000000002cf045f6 6. DB::ReadBuffer::next() @ 0x000000000b528aeb 7. ./build_docker/./src/Server/TCPHandler.cpp:383: DB::TCPHandler::runImpl() @ 0x000000002d174fd3 8. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 12. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 13. asan_thread_start(void*) @ 0x000000000aa43059 14. ? @ 0x00007f35aab92ac3 15. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:07:02.387272 [ 20353 ] {caee35f1-9c06-49bd-abc2-afc8022ed237} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45702) (comment: 01542_dictionary_load_exception_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:02.391241 [ 20353 ] {caee35f1-9c06-49bd-abc2-afc8022ed237} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:02.392507 [ 2688 ] {60f80ee1-a08c-4763-81db-81616e3cc4df} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45736) (comment: 01542_dictionary_load_exception_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:02.395200 [ 20353 ] {caee35f1-9c06-49bd-abc2-afc8022ed237} TCPHandler: Client has gone away. 2025.09.09 15:07:02.395220 [ 20355 ] {} ServerErrorHandler: Code: 210. DB::NetException: Connection reset by peer, while reading from socket (peer: [::1]:45708, 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 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&&) @ 0x000000001b0b7a5f 3. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:83: DB::ReadBufferFromPocoSocketBase::socketReceiveBytesImpl(char*, unsigned long) @ 0x000000001b0b6042 4. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:107: DB::ReadBufferFromPocoSocketBase::nextImpl() @ 0x000000001b0b6b84 5. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:103: DB::ReadBufferFromPocoSocketChunked::nextImpl() @ 0x000000002cf045f6 6. DB::ReadBuffer::next() @ 0x000000000b528aeb 7. ./build_docker/./src/Server/TCPHandler.cpp:383: DB::TCPHandler::runImpl() @ 0x000000002d174fd3 8. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 12. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 13. asan_thread_start(void*) @ 0x000000000aa43059 14. ? @ 0x00007f35aab92ac3 15. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:07:02.395367 [ 2688 ] {60f80ee1-a08c-4763-81db-81616e3cc4df} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:02.397072 [ 2688 ] {60f80ee1-a08c-4763-81db-81616e3cc4df} TCPHandler: Client has gone away. 2025.09.09 15:07:02.415047 [ 20881 ] {7c730bc3-4618-452d-a340-6de85b1a2066} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45720) (comment: 01542_dictionary_load_exception_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:02.417675 [ 20881 ] {7c730bc3-4618-452d-a340-6de85b1a2066} TCPHandler: Can't send logs to client: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::1]:9000 -> [::1]:45720). (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 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&&) @ 0x000000001b0b7a5f 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:169: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000001b0bada2 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:201: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000002cf09bf7 5. ./src/IO/WriteBuffer.h:66: DB::TCPHandler::sendLogData(DB::Block const&) @ 0x000000002d1a9beb 6. ./contrib/llvm-project/libcxx/include/__hash_table:1473: DB::TCPHandler::sendLogs() @ 0x000000002d18db59 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d176902 8. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 12. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 13. asan_thread_start(void*) @ 0x000000000aa43059 14. ? @ 0x00007f35aab92ac3 15. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:07:02.422122 [ 20881 ] {7c730bc3-4618-452d-a340-6de85b1a2066} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:02.424472 [ 20881 ] {7c730bc3-4618-452d-a340-6de85b1a2066} TCPHandler: Client has gone away. 2025.09.09 15:07:02.458674 [ 20379 ] {0bc0bf41-3a69-4ba7-9680-5f10938bcc9d} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45746) (comment: 01542_dictionary_load_exception_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:02.466495 [ 20379 ] {0bc0bf41-3a69-4ba7-9680-5f10938bcc9d} TCPHandler: Can't send logs to client: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::1]:9000 -> [::1]:45746). (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 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&&) @ 0x000000001b0b7a5f 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:169: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000001b0bada2 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:201: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000002cf09bf7 5. ./src/IO/WriteBuffer.h:66: DB::TCPHandler::sendLogData(DB::Block const&) @ 0x000000002d1a9beb 6. ./contrib/llvm-project/libcxx/include/__hash_table:1473: DB::TCPHandler::sendLogs() @ 0x000000002d18db59 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d176902 8. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 12. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 13. asan_thread_start(void*) @ 0x000000000aa43059 14. ? @ 0x00007f35aab92ac3 15. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:07:02.472571 [ 20379 ] {0bc0bf41-3a69-4ba7-9680-5f10938bcc9d} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:02.475824 [ 20379 ] {0bc0bf41-3a69-4ba7-9680-5f10938bcc9d} TCPHandler: Client has gone away. 2025.09.09 15:07:02.530020 [ 2957 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:07:02.531258 [ 2970 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:07:02.622850 [ 2978 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:07:02.776500 [ 3494 ] {} test_0473czib.mt (37fd3cf2-879f-4934-ac8d-662471988a31): dropAllData: got exception removing parts from disk, removing successfully removed parts from memory. 2025.09.09 15:07:02.781546 [ 3494 ] {} DatabaseCatalog: Cannot drop table test_0473czib.mt (37fd3cf2-879f-4934-ac8d-662471988a31). 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af80b71 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80746 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000263a174e 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002c47c445 8. ./contrib/llvm-project/libcxx/include/vector:547: DB::MergeTreeData::clearPartsFromFilesystem(std::vector, std::allocator>> const&, bool, std::unordered_set, std::equal_to, std::allocator>*) @ 0x000000002c47a78e 9. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::dropAllData() @ 0x000000002c4862d9 10. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::dropTableFinally(DB::DatabaseCatalog::TableMarkedAsDropped const&) @ 0x00000000286c7c77 11. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: void std::__function::__policy_invoker::__call_impl, std::allocator>>)::$_0, void ()>>(std::__function::__policy_storage const*) @ 0x00000000286d9744 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000263a3ea5 13. ./contrib/llvm-project/libcxx/include/future:0: std::packaged_task::operator()() @ 0x000000001bba33ac 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7eaf0 15. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001af8a79f 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 18. asan_thread_start(void*) @ 0x000000000aa43059 19. ? @ 0x00007f35aab92ac3 20. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:07:02.851092 [ 2688 ] {f5006dd8-6ff5-4283-901d-b6dbdc73e876} executeQuery: Code: 62. DB::Exception: Cannot TRUNCATE dictionary. (SYNTAX_ERROR) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45770) (comment: 01542_dictionary_load_exception_race.sh) (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aac868e 4. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:262: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x00000000291f1adc 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>>>&) @ 0x00000000291f510c 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:361: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000291edc97 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x00000000291ebf11 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x00000000291eb7ed 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b382fc 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 15:07:02.857030 [ 2688 ] {f5006dd8-6ff5-4283-901d-b6dbdc73e876} 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aac868e 4. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:262: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x00000000291f1adc 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>>>&) @ 0x00000000291f510c 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:361: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000291edc97 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x00000000291ebf11 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x00000000291eb7ed 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b382fc 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 15:07:03.170304 [ 3004 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:07:03.451154 [ 2688 ] {dd449400-52a1-4984-adb6-cb511155532d} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45786) (comment: 01542_dictionary_load_exception_race.sh) (in query: DROP DATABASE IF EXISTS database_for_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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aac868e 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x00000000286b57c7 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x00000000291f5630 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:361: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000291edc97 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x00000000291ebf11 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x00000000291eb7ed 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b382fc 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 15:07:03.456364 [ 2688 ] {dd449400-52a1-4984-adb6-cb511155532d} TCPHandler: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aac868e 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x00000000286b57c7 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x00000000291f5630 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:361: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000291edc97 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x00000000291ebf11 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x00000000291eb7ed 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b382fc 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 15:07:03.537855 [ 3046 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:07:03.538609 [ 3042 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:07:03.625367 [ 3054 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:07:04.184565 [ 3093 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:07:04.464583 [ 5438 ] {a6aca5d9-6e47-4176-8c76-f0a7bb05b057} WriteBufferFromS3: WriteBufferFromS3 was neither finished nor aborted, try to abort upload in destructor. Details: bucket test, key s3/yjr/hetrylosfezjrhmvnjrytpeurrgwa, total size 83886080, count 83886080, hidden_size 0, offset 0, with pool: true, prefinalized false, finalized false, upload id NWYxMWFmMGEtMzRkNS00OWVjLTgzYTAtMjkwNWNlMWMyNjE1LmNlNDQzNzFkLTc4ZGQtNDVkZC1iNzNjLWZiZGExYzUyMGVkMHgxNzU3NDIzMjIzNTAyNjEwNjQx, upload has finished false. 2025.09.09 15:07:04.466013 [ 5438 ] {a6aca5d9-6e47-4176-8c76-f0a7bb05b057} WriteBufferFromS3: Abort multipart upload. Details: bucket test, key s3/yjr/hetrylosfezjrhmvnjrytpeurrgwa, total size 83886080, count 83886080, hidden_size 0, offset 0, with pool: true, prefinalized false, finalized false, upload id NWYxMWFmMGEtMzRkNS00OWVjLTgzYTAtMjkwNWNlMWMyNjE1LmNlNDQzNzFkLTc4ZGQtNDVkZC1iNzNjLWZiZGExYzUyMGVkMHgxNzU3NDIzMjIzNTAyNjEwNjQx, upload has finished false 2025.09.09 15:07:04.550777 [ 5438 ] {a6aca5d9-6e47-4176-8c76-f0a7bb05b057} WriteBufferFromS3: Multipart upload has aborted successfully. Details: bucket test, key s3/yjr/hetrylosfezjrhmvnjrytpeurrgwa, total size 83886080, count 83886080, hidden_size 0, offset 0, with pool: true, prefinalized false, finalized false, upload id NWYxMWFmMGEtMzRkNS00OWVjLTgzYTAtMjkwNWNlMWMyNjE1LmNlNDQzNzFkLTc4ZGQtNDVkZC1iNzNjLWZiZGExYzUyMGVkMHgxNzU3NDIzMjIzNTAyNjEwNjQx, upload has finished false 2025.09.09 15:07:04.582125 [ 3109 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:07:04.632578 [ 3094 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:07:04.633173 [ 3127 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:07:05.056085 [ 20882 ] {a6aca5d9-6e47-4176-8c76-f0a7bb05b057} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=4, jobs=3). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45630) (comment: 02789_filesystem_cache_alignment.sh) (in query: INSERT INTO test SELECT number, randomString(100) FROM numbers(1000000);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af80b71 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80746 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002699bf33 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000002699ba34 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:1197: ? @ 0x0000000026b1a342 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000026afbbd3 10. ./contrib/llvm-project/libcxx/include/__split_buffer:88: DB::WriteBufferFromS3::writeMultipartUpload() @ 0x0000000026ae9e77 11. ./build_docker/./src/IO/WriteBufferFromS3.cpp:144: DB::WriteBufferFromS3::nextImpl() @ 0x0000000026ae89d7 12. ./src/IO/WriteBuffer.h:66: DB::WriteBufferFromFileDecorator::nextImpl() @ 0x00000000280d2dcb 13. ./src/IO/WriteBuffer.h:66: DB::HashingWriteBuffer::nextImpl() @ 0x000000002c2571d3 14. DB::WriteBuffer::write(char const*, unsigned long) @ 0x000000000aacde3b 15. ./build_docker/./src/Compression/CompressedWriteBuffer.cpp:56: DB::CompressedWriteBuffer::nextImpl() @ 0x0000000027765d9e 16. ./src/IO/WriteBuffer.h:66: DB::HashingWriteBuffer::nextImpl() @ 0x000000002c2571d3 17. ./src/IO/WriteBuffer.h:0: void std::__function::__policy_invoker::__call_impl::immutable_ptr const&, std::set, std::allocator>&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x000000002c626c6b 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000027a9e455 19. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:106: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x0000000027a9ea65 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002c61ef5c 21. ./contrib/llvm-project/libcxx/include/unordered_map:1805: DB::MergeTreeDataPartWriterWide::writeColumn(DB::NameAndTypePair const&, DB::IColumn const&, std::set, std::allocator>&, std::vector> const&) @ 0x000000002c61d087 22. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:328: DB::MergeTreeDataPartWriterWide::write(DB::Block const&, DB::PODArray, 63ul, 64ul> const*) @ 0x000000002c61a79f 23. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:368: DB::MergedBlockOutputStream::writeWithPermutation(DB::Block const&, DB::PODArray, 63ul, 64ul> const*) @ 0x000000002c8dd45c 24. ./build_docker/./src/Storages/MergeTree/MergeTreeDataWriter.cpp:0: DB::MergeTreeDataWriter::writeTempPartImpl(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr, long, bool) @ 0x000000002c95d36a 25. ./build_docker/./src/Storages/MergeTree/MergeTreeDataWriter.cpp:444: DB::MergeTreeDataWriter::writeTempPart(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002c958ddf 26. ./build_docker/./src/Storages/MergeTree/MergeTreeSink.cpp:0: DB::MergeTreeSink::consume(DB::Chunk&) @ 0x000000002cc2a689 27. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:11: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000002dbe182e 28. ./contrib/llvm-project/libcxx/include/vector:432: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000002d9c1a3a 29. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:102: DB::runStep(std::function, DB::ThreadStatus*, std::atomic*) @ 0x000000002d9c1551 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d9c06a6 31. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 2025.09.09 15:07:05.060801 [ 20882 ] {a6aca5d9-6e47-4176-8c76-f0a7bb05b057} TCPHandler: 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af80b71 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80746 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002699bf33 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000002699ba34 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:1197: ? @ 0x0000000026b1a342 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000026afbbd3 10. ./contrib/llvm-project/libcxx/include/__split_buffer:88: DB::WriteBufferFromS3::writeMultipartUpload() @ 0x0000000026ae9e77 11. ./build_docker/./src/IO/WriteBufferFromS3.cpp:144: DB::WriteBufferFromS3::nextImpl() @ 0x0000000026ae89d7 12. ./src/IO/WriteBuffer.h:66: DB::WriteBufferFromFileDecorator::nextImpl() @ 0x00000000280d2dcb 13. ./src/IO/WriteBuffer.h:66: DB::HashingWriteBuffer::nextImpl() @ 0x000000002c2571d3 14. DB::WriteBuffer::write(char const*, unsigned long) @ 0x000000000aacde3b 15. ./build_docker/./src/Compression/CompressedWriteBuffer.cpp:56: DB::CompressedWriteBuffer::nextImpl() @ 0x0000000027765d9e 16. ./src/IO/WriteBuffer.h:66: DB::HashingWriteBuffer::nextImpl() @ 0x000000002c2571d3 17. ./src/IO/WriteBuffer.h:0: void std::__function::__policy_invoker::__call_impl::immutable_ptr const&, std::set, std::allocator>&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x000000002c626c6b 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000027a9e455 19. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:106: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x0000000027a9ea65 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002c61ef5c 21. ./contrib/llvm-project/libcxx/include/unordered_map:1805: DB::MergeTreeDataPartWriterWide::writeColumn(DB::NameAndTypePair const&, DB::IColumn const&, std::set, std::allocator>&, std::vector> const&) @ 0x000000002c61d087 22. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:328: DB::MergeTreeDataPartWriterWide::write(DB::Block const&, DB::PODArray, 63ul, 64ul> const*) @ 0x000000002c61a79f 23. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:368: DB::MergedBlockOutputStream::writeWithPermutation(DB::Block const&, DB::PODArray, 63ul, 64ul> const*) @ 0x000000002c8dd45c 24. ./build_docker/./src/Storages/MergeTree/MergeTreeDataWriter.cpp:0: DB::MergeTreeDataWriter::writeTempPartImpl(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr, long, bool) @ 0x000000002c95d36a 25. ./build_docker/./src/Storages/MergeTree/MergeTreeDataWriter.cpp:444: DB::MergeTreeDataWriter::writeTempPart(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002c958ddf 26. ./build_docker/./src/Storages/MergeTree/MergeTreeSink.cpp:0: DB::MergeTreeSink::consume(DB::Chunk&) @ 0x000000002cc2a689 27. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:11: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000002dbe182e 28. ./contrib/llvm-project/libcxx/include/vector:432: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000002d9c1a3a 29. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:102: DB::runStep(std::function, DB::ThreadStatus*, std::atomic*) @ 0x000000002d9c1551 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d9c06a6 31. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 2025.09.09 15:07:05.188072 [ 3185 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:07:05.586628 [ 3206 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:07:05.635234 [ 3213 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:07:05.636583 [ 3222 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:07:06.253788 [ 2751 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:07:06.488717 [ 20379 ] {f3421eb9-f889-4ff4-b923-f3e7fff0966c} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45838) (comment: 01542_dictionary_load_exception_race.sh) (in query: DROP DATABASE IF EXISTS database_for_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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aac868e 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x00000000286b57c7 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x00000000291f5630 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:361: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000291edc97 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x00000000291ebf11 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x00000000291eb7ed 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b382fc 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 15:07:06.490875 [ 20379 ] {f3421eb9-f889-4ff4-b923-f3e7fff0966c} TCPHandler: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aac868e 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x00000000286b57c7 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x00000000291f5630 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:361: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000291edc97 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x00000000291ebf11 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x00000000291eb7ed 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b382fc 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 15:07:06.591273 [ 2801 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:07:06.641201 [ 2809 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:07:06.641608 [ 2802 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:07:07.256531 [ 2836 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:07:07.375403 [ 20379 ] {06f14cb4-71ed-4b60-95f9-82be91876b35} executeQuery: Code: 82. DB::Exception: Database database_for_dict already exists. (DATABASE_ALREADY_EXISTS) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45854) (comment: 01542_dictionary_load_exception_race.sh) (in query: CREATE DATABASE database_for_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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x000000000aafc574 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:146: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002918fd00 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000291c33d8 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b382fc 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 9. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 13. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 14. asan_thread_start(void*) @ 0x000000000aa43059 15. ? @ 0x00007f35aab92ac3 16. ? @ 0x00007f35aac24850 2025.09.09 15:07:07.396486 [ 20379 ] {06f14cb4-71ed-4b60-95f9-82be91876b35} TCPHandler: Code: 82. DB::Exception: Database database_for_dict already exists. (DATABASE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x000000000aafc574 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:146: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002918fd00 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000291c33d8 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b382fc 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 9. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 13. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 14. asan_thread_start(void*) @ 0x000000000aa43059 15. ? @ 0x00007f35aab92ac3 16. ? @ 0x00007f35aac24850 2025.09.09 15:07:07.593084 [ 2892 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:07:07.643425 [ 2877 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:07:07.646728 [ 2877 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:07:08.073999 [ 5903 ] {} test_0473czib.mt (37fd3cf2-879f-4934-ac8d-662471988a31): dropAllData: got exception removing parts from disk, removing successfully removed parts from memory. 2025.09.09 15:07:08.082295 [ 5903 ] {} DatabaseCatalog: Cannot drop table test_0473czib.mt (37fd3cf2-879f-4934-ac8d-662471988a31). 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af819ed 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80746 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000263a174e 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002c47c445 8. ./contrib/llvm-project/libcxx/include/vector:547: DB::MergeTreeData::clearPartsFromFilesystem(std::vector, std::allocator>> const&, bool, std::unordered_set, std::equal_to, std::allocator>*) @ 0x000000002c47a78e 9. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::dropAllData() @ 0x000000002c4862d9 10. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::dropTableFinally(DB::DatabaseCatalog::TableMarkedAsDropped const&) @ 0x00000000286c7c77 11. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: void std::__function::__policy_invoker::__call_impl, std::allocator>>)::$_0, void ()>>(std::__function::__policy_storage const*) @ 0x00000000286d9744 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000263a3ea5 13. ./contrib/llvm-project/libcxx/include/future:0: std::packaged_task::operator()() @ 0x000000001bba33ac 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7eaf0 15. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001af8a79f 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 18. asan_thread_start(void*) @ 0x000000000aa43059 19. ? @ 0x00007f35aab92ac3 20. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:07:08.258568 [ 2951 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:07:08.406008 [ 20345 ] {bf6d9c29-662e-4fb4-ac23-e8ce5ae6ee95} executeQuery: Code: 42. DB::Exception: Number of arguments for function BLAKE3 doesn't match: passed 2, should be 1: In scope SELECT BLAKE3(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT BLAKE3(NULL, NULL);) 2025.09.09 15:07:08.415116 [ 20345 ] {bf6d9c29-662e-4fb4-ac23-e8ce5ae6ee95} TCPHandler: Code: 42. DB::Exception: Number of arguments for function BLAKE3 doesn't match: passed 2, should be 1: In scope SELECT BLAKE3(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:07:08.476863 [ 20345 ] {d3588d5d-5eee-4e85-a416-38fc0a2ed695} executeQuery: Code: 43. DB::Exception: Second argument to CAST must be a constant string describing type. Instead there is a column with the following structure: Const(size = 1, Nullable(size = 1, Nothing(size = 1), UInt8(size = 1))): In scope SELECT CAST(NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT CAST(NULL, NULL);) 2025.09.09 15:07:08.480248 [ 20345 ] {d3588d5d-5eee-4e85-a416-38fc0a2ed695} TCPHandler: Code: 43. DB::Exception: Second argument to CAST must be a constant string describing type. Instead there is a column with the following structure: Const(size = 1, Nullable(size = 1, Nothing(size = 1), UInt8(size = 1))): In scope SELECT CAST(NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.09.09 15:07:08.543072 [ 20345 ] {48c0a522-442d-4498-ac07-ae2f04db07f0} executeQuery: Code: 42. DB::Exception: Number of arguments for function lengthUTF8 doesn't match: passed 2, should be 1: In scope SELECT CHARACTER_LENGTH(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT CHARACTER_LENGTH(NULL, NULL);) 2025.09.09 15:07:08.546142 [ 20345 ] {48c0a522-442d-4498-ac07-ae2f04db07f0} TCPHandler: Code: 42. DB::Exception: Number of arguments for function lengthUTF8 doesn't match: passed 2, should be 1: In scope SELECT CHARACTER_LENGTH(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:07:08.562957 [ 20379 ] {c6c41d88-2c56-4486-b48a-9543a0a3ca1d} executeQuery: Code: 57. DB::Exception: Table database_for_dict.table_for_dict already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:51808) (comment: 01542_dictionary_load_exception_race.sh) (in query: CREATE TABLE database_for_dict.table_for_dict (`key_column` UInt64, `second_column` UInt64, `third_column` String) ENGINE = MergeTree ORDER BY key_column SETTINGS index_granularity = 60578, min_bytes_for_wide_part = 592817471, ratio_of_defaults_for_sparse_serialization = 0.3581370711326599, replace_long_file_name_to_hash = false, max_file_name_length = 60, min_bytes_for_full_part_storage = 510714276, compact_parts_max_bytes_to_buffer = 480424706, compact_parts_max_granules_to_buffer = 127, compact_parts_merge_max_bytes_to_prefetch_part = 31072451, merge_max_block_size = 24278, old_parts_lifetime = 480., prefer_fetch_merged_part_size_threshold = 10737418240, vertical_merge_algorithm_min_rows_to_activate = 1000000, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 10737418240, index_granularity_bytes = 3546291, concurrent_part_removal_threshold = 14, allow_vertical_merges_from_compact_to_wide_parts = true, cache_populated_by_fetch = true, marks_compress_block_size = 74214, primary_key_compress_block_size = 17858), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa91e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1558: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291bc5ff 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291ac835 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000291c3415 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b382fc 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 15. asan_thread_start(void*) @ 0x000000000aa43059 16. ? @ 0x00007f35aab92ac3 17. ? @ 0x00007f35aac24850 2025.09.09 15:07:08.566471 [ 20379 ] {c6c41d88-2c56-4486-b48a-9543a0a3ca1d} TCPHandler: Code: 57. DB::Exception: Table database_for_dict.table_for_dict already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa91e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1558: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291bc5ff 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291ac835 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000291c3415 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b382fc 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 15. asan_thread_start(void*) @ 0x000000000aa43059 16. ? @ 0x00007f35aab92ac3 17. ? @ 0x00007f35aac24850 2025.09.09 15:07:08.595216 [ 2969 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:07:08.599538 [ 20345 ] {02240ac7-5189-4841-a913-d1d41f807aa3} executeQuery: Code: 42. DB::Exception: Number of arguments for function lengthUTF8 doesn't match: passed 2, should be 1: In scope SELECT CHAR_LENGTH(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT CHAR_LENGTH(NULL, NULL);) 2025.09.09 15:07:08.602854 [ 20345 ] {02240ac7-5189-4841-a913-d1d41f807aa3} TCPHandler: Code: 42. DB::Exception: Number of arguments for function lengthUTF8 doesn't match: passed 2, should be 1: In scope SELECT CHAR_LENGTH(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:07:08.645045 [ 2985 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:07:08.648635 [ 3008 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:07:08.962814 [ 20345 ] {86ccd005-f415-4bf9-b949-25d4882fcfed} executeQuery: Code: 42. DB::Exception: Number of arguments for function CRC32 doesn't match: passed 2, should be 1: In scope SELECT CRC32(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT CRC32(NULL, NULL);) 2025.09.09 15:07:08.966368 [ 20345 ] {86ccd005-f415-4bf9-b949-25d4882fcfed} TCPHandler: Code: 42. DB::Exception: Number of arguments for function CRC32 doesn't match: passed 2, should be 1: In scope SELECT CRC32(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:07:09.013583 [ 20345 ] {8f515217-dfc8-461b-93f4-90c15ed63786} executeQuery: Code: 42. DB::Exception: Number of arguments for function CRC32IEEE doesn't match: passed 2, should be 1: In scope SELECT CRC32IEEE(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT CRC32IEEE(NULL, NULL);) 2025.09.09 15:07:09.017109 [ 20345 ] {8f515217-dfc8-461b-93f4-90c15ed63786} TCPHandler: Code: 42. DB::Exception: Number of arguments for function CRC32IEEE doesn't match: passed 2, should be 1: In scope SELECT CRC32IEEE(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:07:09.102655 [ 20345 ] {df6f907c-91d9-4609-9b2e-ac91b1a6dd7f} executeQuery: Code: 42. DB::Exception: Number of arguments for function CRC64 doesn't match: passed 2, should be 1: In scope SELECT CRC64(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT CRC64(NULL, NULL);) 2025.09.09 15:07:09.108223 [ 20345 ] {df6f907c-91d9-4609-9b2e-ac91b1a6dd7f} TCPHandler: Code: 42. DB::Exception: Number of arguments for function CRC64 doesn't match: passed 2, should be 1: In scope SELECT CRC64(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:07:09.260212 [ 3045 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:07:09.317831 [ 20345 ] {6c52ac2e-03db-429d-bf27-afaa2f94c527} executeQuery: Code: 42. DB::Exception: Number of arguments for function currentDatabase doesn't match: passed 2, should be 0: In scope SELECT DATABASE(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT DATABASE(NULL, NULL);) 2025.09.09 15:07:09.320852 [ 20345 ] {6c52ac2e-03db-429d-bf27-afaa2f94c527} TCPHandler: Code: 42. DB::Exception: Number of arguments for function currentDatabase doesn't match: passed 2, should be 0: In scope SELECT DATABASE(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:07:09.597390 [ 3055 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:07:09.647537 [ 3048 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:07:09.651302 [ 3068 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:07:10.098122 [ 20379 ] {83264c1c-be11-4f53-8e99-1ce3dbfbc4ce} executeQuery: Code: 62. DB::Exception: Cannot TRUNCATE dictionary. (SYNTAX_ERROR) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:51828) (comment: 01542_dictionary_load_exception_race.sh) (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aac868e 4. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:262: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x00000000291f1adc 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>>>&) @ 0x00000000291f510c 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:361: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000291edc97 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x00000000291ebf11 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x00000000291eb7ed 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b382fc 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 15:07:10.122499 [ 20379 ] {83264c1c-be11-4f53-8e99-1ce3dbfbc4ce} 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aac868e 4. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:262: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x00000000291f1adc 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>>>&) @ 0x00000000291f510c 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:361: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000291edc97 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x00000000291ebf11 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x00000000291eb7ed 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b382fc 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 15:07:10.263011 [ 3084 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:07:10.600150 [ 3093 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:07:10.649912 [ 3069 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:07:10.653662 [ 3082 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:07:10.767299 [ 20345 ] {fe3f585e-e032-4c26-bc99-b8c61dadb7b4} executeQuery: Code: 42. DB::Exception: Number of arguments for function formatReadableSize doesn't match: passed 2, should be 1: In scope SELECT FORMAT_BYTES(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT FORMAT_BYTES(NULL, NULL);) 2025.09.09 15:07:10.781756 [ 20345 ] {fe3f585e-e032-4c26-bc99-b8c61dadb7b4} TCPHandler: Code: 42. DB::Exception: Number of arguments for function formatReadableSize doesn't match: passed 2, should be 1: In scope SELECT FORMAT_BYTES(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:07:10.844957 [ 20345 ] {34ddf29c-70a7-440a-a3a0-b2460f1db2b8} executeQuery: Code: 42. DB::Exception: Number of arguments for function FQDN doesn't match: passed 2, should be 0: In scope SELECT FQDN(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT FQDN(NULL, NULL);) 2025.09.09 15:07:10.848196 [ 20345 ] {34ddf29c-70a7-440a-a3a0-b2460f1db2b8} TCPHandler: Code: 42. DB::Exception: Number of arguments for function FQDN doesn't match: passed 2, should be 0: In scope SELECT FQDN(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:07:10.863504 [ 20379 ] {da92b014-1bd8-4b1c-a527-72c703deb2eb} executeQuery: Code: 82. DB::Exception: Database ordinary_db already exists. (DATABASE_ALREADY_EXISTS) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:51838) (comment: 01542_dictionary_load_exception_race.sh) (in query: CREATE DATABASE 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x000000000aafc574 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:146: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002918fd00 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000291c33d8 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b382fc 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 9. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 13. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 14. asan_thread_start(void*) @ 0x000000000aa43059 15. ? @ 0x00007f35aab92ac3 16. ? @ 0x00007f35aac24850 2025.09.09 15:07:10.896524 [ 20379 ] {da92b014-1bd8-4b1c-a527-72c703deb2eb} TCPHandler: Code: 82. DB::Exception: Database ordinary_db already exists. (DATABASE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x000000000aafc574 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:146: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002918fd00 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000291c33d8 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b382fc 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 9. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 13. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 14. asan_thread_start(void*) @ 0x000000000aa43059 15. ? @ 0x00007f35aab92ac3 16. ? @ 0x00007f35aac24850 2025.09.09 15:07:10.972893 [ 20345 ] {2481cabf-27ab-438e-a549-20bf29bd9b4e} executeQuery: Code: 42. DB::Exception: Number of arguments for function base64Decode doesn't match: passed 2, should be 1: In scope SELECT FROM_BASE64(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT FROM_BASE64(NULL, NULL);) 2025.09.09 15:07:10.992498 [ 20345 ] {2481cabf-27ab-438e-a549-20bf29bd9b4e} TCPHandler: Code: 42. DB::Exception: Number of arguments for function base64Decode doesn't match: passed 2, should be 1: In scope SELECT FROM_BASE64(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:07:11.126433 [ 20345 ] {e13cced9-f4bd-4e96-bd70-726bf5cae352} executeQuery: Code: 42. DB::Exception: Number of arguments for function fromDaysSinceYearZero doesn't match: passed 2, should be 1: In scope SELECT FROM_DAYS(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT FROM_DAYS(NULL, NULL);) 2025.09.09 15:07:11.133547 [ 20345 ] {e13cced9-f4bd-4e96-bd70-726bf5cae352} TCPHandler: Code: 42. DB::Exception: Number of arguments for function fromDaysSinceYearZero doesn't match: passed 2, should be 1: In scope SELECT FROM_DAYS(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:07:11.265176 [ 3075 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:07:11.478794 [ 20379 ] {e3bcf13c-1906-42c2-a131-8cb724799780} executeQuery: Code: 387. DB::Exception: Dictionary ordinary_db.dict1 already exists. (DICTIONARY_ALREADY_EXISTS) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:51854) (comment: 01542_dictionary_load_exception_race.sh) (in query: CREATE DICTIONARY ordinary_db.dict1 (`key_column` UInt64 DEFAULT 0, `second_column` UInt64 DEFAULT 1, `third_column` String DEFAULT 'qqq') PRIMARY KEY key_column SOURCE(CLICKHOUSE(HOST 'localhost' PORT tcpPort() USER 'default' TABLE 'table_for_dict' PASSWORD '[HIDDEN]' DB 'database_for_dict')) LIFETIME(MIN 1 MAX 10) LAYOUT(FLAT()) SETTINGS(max_result_bytes = 1)), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa91e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1555: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291bc592 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291ac835 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000291c3415 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b382fc 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 15. asan_thread_start(void*) @ 0x000000000aa43059 16. ? @ 0x00007f35aab92ac3 17. ? @ 0x00007f35aac24850 2025.09.09 15:07:11.482019 [ 20379 ] {e3bcf13c-1906-42c2-a131-8cb724799780} TCPHandler: Code: 387. DB::Exception: Dictionary ordinary_db.dict1 already exists. (DICTIONARY_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa91e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1555: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291bc592 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291ac835 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000291c3415 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b382fc 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 15. asan_thread_start(void*) @ 0x000000000aa43059 16. ? @ 0x00007f35aab92ac3 17. ? @ 0x00007f35aac24850 2025.09.09 15:07:11.497129 [ 20345 ] {da30f049-a9ae-45f0-8884-dbd39ac87f55} executeQuery: Code: 42. DB::Exception: Number of arguments for function IPv6StringToNum doesn't match: passed 2, should be 1: In scope SELECT INET6_ATON(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT INET6_ATON(NULL, NULL);) 2025.09.09 15:07:11.504170 [ 20345 ] {da30f049-a9ae-45f0-8884-dbd39ac87f55} TCPHandler: Code: 42. DB::Exception: Number of arguments for function IPv6StringToNum doesn't match: passed 2, should be 1: In scope SELECT INET6_ATON(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:07:11.603069 [ 3102 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:07:11.613325 [ 20345 ] {e903e721-0089-4d4e-b3fc-c54a91ba97ad} executeQuery: Code: 42. DB::Exception: Number of arguments for function IPv6NumToString doesn't match: passed 2, should be 1: In scope SELECT INET6_NTOA(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT INET6_NTOA(NULL, NULL);) 2025.09.09 15:07:11.631889 [ 20345 ] {e903e721-0089-4d4e-b3fc-c54a91ba97ad} TCPHandler: Code: 42. DB::Exception: Number of arguments for function IPv6NumToString doesn't match: passed 2, should be 1: In scope SELECT INET6_NTOA(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:07:11.652415 [ 3101 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:07:11.657956 [ 3118 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:07:12.005523 [ 20345 ] {83153f16-2d2c-4dfd-ae2e-52c29a8bb8b4} executeQuery: Code: 42. DB::Exception: Number of arguments for function IPv4StringToNum doesn't match: passed 2, should be 1: In scope SELECT INET_ATON(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT INET_ATON(NULL, NULL);) 2025.09.09 15:07:12.016242 [ 20345 ] {83153f16-2d2c-4dfd-ae2e-52c29a8bb8b4} TCPHandler: Code: 42. DB::Exception: Number of arguments for function IPv4StringToNum doesn't match: passed 2, should be 1: In scope SELECT INET_ATON(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:07:12.153989 [ 20345 ] {a686fceb-35db-4c28-8347-5e3e91d623fb} executeQuery: Code: 42. DB::Exception: Number of arguments for function IPv4NumToString doesn't match: passed 2, should be 1: In scope SELECT INET_NTOA(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT INET_NTOA(NULL, NULL);) 2025.09.09 15:07:12.157133 [ 20345 ] {a686fceb-35db-4c28-8347-5e3e91d623fb} TCPHandler: Code: 42. DB::Exception: Number of arguments for function IPv4NumToString doesn't match: passed 2, should be 1: In scope SELECT INET_NTOA(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:07:12.266915 [ 3135 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:07:12.270319 [ 5356 ] {} ExternalDictionariesLoader: Could not load external dictionary 'b9456353-118f-4e69-ac1b-88d4f6a6e618', next update is scheduled at 2025-09-09 15:07:20: 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:07:12.372128 [ 20345 ] {0ba68454-15c5-4acf-b795-97ce0a2d8542} executeQuery: Code: 42. DB::Exception: Number of arguments for function IPv4NumToString doesn't match: passed 2, should be 1: In scope SELECT IPv4NumToString(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT IPv4NumToString(NULL, NULL);) 2025.09.09 15:07:12.374699 [ 20345 ] {0ba68454-15c5-4acf-b795-97ce0a2d8542} TCPHandler: Code: 42. DB::Exception: Number of arguments for function IPv4NumToString doesn't match: passed 2, should be 1: In scope SELECT IPv4NumToString(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:07:12.409848 [ 20345 ] {961c6b2c-e55c-4973-bd2e-0b01166bb676} executeQuery: Code: 42. DB::Exception: Number of arguments for function IPv4NumToStringClassC doesn't match: passed 2, should be 1: In scope SELECT IPv4NumToStringClassC(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT IPv4NumToStringClassC(NULL, NULL);) 2025.09.09 15:07:12.412740 [ 20345 ] {961c6b2c-e55c-4973-bd2e-0b01166bb676} TCPHandler: Code: 42. DB::Exception: Number of arguments for function IPv4NumToStringClassC doesn't match: passed 2, should be 1: In scope SELECT IPv4NumToStringClassC(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:07:12.458314 [ 20379 ] {bba3f33f-cef9-410a-9fe1-83d8e1f4826c} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:51870) (comment: 01542_dictionary_load_exception_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:12.460140 [ 20379 ] {bba3f33f-cef9-410a-9fe1-83d8e1f4826c} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:12.472044 [ 20884 ] {ac4309f1-739f-4973-a6f6-a38303a3d97f} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:51926) (comment: 01542_dictionary_load_exception_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:12.480102 [ 19252 ] {f2e6b725-ac9a-4e3e-9486-8778783dbd61} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:51900) (comment: 01542_dictionary_load_exception_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:12.484109 [ 19252 ] {f2e6b725-ac9a-4e3e-9486-8778783dbd61} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:12.486617 [ 20884 ] {ac4309f1-739f-4973-a6f6-a38303a3d97f} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:12.504512 [ 20345 ] {47ae70b3-0587-4814-924b-f90079a7e506} executeQuery: Code: 42. DB::Exception: Number of arguments for function IPv4StringToNum doesn't match: passed 2, should be 1: In scope SELECT IPv4StringToNum(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT IPv4StringToNum(NULL, NULL);) 2025.09.09 15:07:12.508336 [ 3612 ] {9000cbdd-25b5-41bc-b3bf-03e247069e4c} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:51934) (comment: 01542_dictionary_load_exception_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:12.509205 [ 3722 ] {94a7d010-7c3d-4c18-87e1-98ef761c74b6} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:51894) (comment: 01542_dictionary_load_exception_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:12.509568 [ 20345 ] {47ae70b3-0587-4814-924b-f90079a7e506} TCPHandler: Code: 42. DB::Exception: Number of arguments for function IPv4StringToNum doesn't match: passed 2, should be 1: In scope SELECT IPv4StringToNum(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:07:12.514848 [ 3612 ] {9000cbdd-25b5-41bc-b3bf-03e247069e4c} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:12.518745 [ 3722 ] {94a7d010-7c3d-4c18-87e1-98ef761c74b6} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:12.546637 [ 20397 ] {774454af-9b95-4b4f-8f1f-5a33498c3899} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:51964) (comment: 01542_dictionary_load_exception_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:12.555006 [ 20397 ] {774454af-9b95-4b4f-8f1f-5a33498c3899} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:12.565691 [ 20882 ] {7c0d7a0e-e12c-4ed7-ba2c-3b3217069e11} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:51940) (comment: 01542_dictionary_load_exception_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:12.566857 [ 20343 ] {339eacf5-22fc-4dd7-bb7c-46917bee2aeb} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:51970) (comment: 01542_dictionary_load_exception_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:12.574757 [ 20882 ] {7c0d7a0e-e12c-4ed7-ba2c-3b3217069e11} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:12.575496 [ 20343 ] {339eacf5-22fc-4dd7-bb7c-46917bee2aeb} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:12.597687 [ 20338 ] {bc13c366-fe50-4237-9eae-ccc91bdf7899} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:51950) (comment: 01542_dictionary_load_exception_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:12.599012 [ 20380 ] {a1e7a3ed-f79f-49c1-b2b8-9164b1b84c0f} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:51886) (comment: 01542_dictionary_load_exception_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:12.599747 [ 20338 ] {bc13c366-fe50-4237-9eae-ccc91bdf7899} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:12.614397 [ 20380 ] {a1e7a3ed-f79f-49c1-b2b8-9164b1b84c0f} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:12.615055 [ 3138 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:07:12.626167 [ 20881 ] {1a8f0126-1c6f-4b17-a52e-5411d1fc326e} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:51936) (comment: 01542_dictionary_load_exception_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:12.629296 [ 20881 ] {1a8f0126-1c6f-4b17-a52e-5411d1fc326e} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:12.656831 [ 3115 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:07:12.660306 [ 3126 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:07:12.695801 [ 20345 ] {cdb35eaf-8e48-4420-8fdc-392f8d4d1733} executeQuery: Code: 42. DB::Exception: Number of arguments for function IPv4StringToNumOrDefault doesn't match: passed 2, should be 1: In scope SELECT IPv4StringToNumOrDefault(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT IPv4StringToNumOrDefault(NULL, NULL);) 2025.09.09 15:07:12.706649 [ 20849 ] {304a63f2-fe66-4dd2-b916-a280b0988d53} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:51914) (comment: 01542_dictionary_load_exception_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:12.718634 [ 20849 ] {304a63f2-fe66-4dd2-b916-a280b0988d53} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:12.780363 [ 20345 ] {cdb35eaf-8e48-4420-8fdc-392f8d4d1733} TCPHandler: Code: 42. DB::Exception: Number of arguments for function IPv4StringToNumOrDefault doesn't match: passed 2, should be 1: In scope SELECT IPv4StringToNumOrDefault(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:07:13.047106 [ 20345 ] {6e6b6ba0-4555-4693-bc08-6a757a7cc55c} executeQuery: Code: 42. DB::Exception: Number of arguments for function IPv4StringToNumOrNull doesn't match: passed 2, should be 1: In scope SELECT IPv4StringToNumOrNull(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT IPv4StringToNumOrNull(NULL, NULL);) 2025.09.09 15:07:13.058786 [ 20345 ] {6e6b6ba0-4555-4693-bc08-6a757a7cc55c} TCPHandler: Code: 42. DB::Exception: Number of arguments for function IPv4StringToNumOrNull doesn't match: passed 2, should be 1: In scope SELECT IPv4StringToNumOrNull(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:07:13.171573 [ 20345 ] {dc77f7fb-46c4-4671-b181-83140f15833e} executeQuery: Code: 42. DB::Exception: Number of arguments for function IPv4ToIPv6 doesn't match: passed 2, should be 1: In scope SELECT IPv4ToIPv6(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT IPv4ToIPv6(NULL, NULL);) 2025.09.09 15:07:13.175846 [ 20345 ] {dc77f7fb-46c4-4671-b181-83140f15833e} TCPHandler: Code: 42. DB::Exception: Number of arguments for function IPv4ToIPv6 doesn't match: passed 2, should be 1: In scope SELECT IPv4ToIPv6(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:07:13.198321 [ 20379 ] {6f3432cd-5bc3-4eb9-95f8-9d85323ab734} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:51982) (comment: 01542_dictionary_load_exception_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:13.211025 [ 20379 ] {6f3432cd-5bc3-4eb9-95f8-9d85323ab734} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:13.215089 [ 20164 ] {} test_0473czib.mt (37fd3cf2-879f-4934-ac8d-662471988a31): dropAllData: got exception removing parts from disk, removing successfully removed parts from memory. 2025.09.09 15:07:13.216412 [ 20164 ] {} DatabaseCatalog: Cannot drop table test_0473czib.mt (37fd3cf2-879f-4934-ac8d-662471988a31). 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af80b71 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80746 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000263a174e 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002c47c445 8. ./contrib/llvm-project/libcxx/include/vector:547: DB::MergeTreeData::clearPartsFromFilesystem(std::vector, std::allocator>> const&, bool, std::unordered_set, std::equal_to, std::allocator>*) @ 0x000000002c47a78e 9. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::dropAllData() @ 0x000000002c4862d9 10. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::dropTableFinally(DB::DatabaseCatalog::TableMarkedAsDropped const&) @ 0x00000000286c7c77 11. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: void std::__function::__policy_invoker::__call_impl, std::allocator>>)::$_0, void ()>>(std::__function::__policy_storage const*) @ 0x00000000286d9744 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000263a3ea5 13. ./contrib/llvm-project/libcxx/include/future:0: std::packaged_task::operator()() @ 0x000000001bba33ac 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7eaf0 15. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001af8a79f 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 18. asan_thread_start(void*) @ 0x000000000aa43059 19. ? @ 0x00007f35aab92ac3 20. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:07:13.268723 [ 3139 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:07:13.450428 [ 20345 ] {c407e901-3bfd-4bc3-8e98-b19eb4e4b952} executeQuery: Code: 42. DB::Exception: Number of arguments for function IPv6NumToString doesn't match: passed 2, should be 1: In scope SELECT IPv6NumToString(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT IPv6NumToString(NULL, NULL);) 2025.09.09 15:07:13.462119 [ 20345 ] {c407e901-3bfd-4bc3-8e98-b19eb4e4b952} TCPHandler: Code: 42. DB::Exception: Number of arguments for function IPv6NumToString doesn't match: passed 2, should be 1: In scope SELECT IPv6NumToString(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:07:13.500917 [ 20884 ] {d5dd755e-3866-4c59-b796-e54438136835} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:52024) (comment: 01542_dictionary_load_exception_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:13.503951 [ 20884 ] {d5dd755e-3866-4c59-b796-e54438136835} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:13.516813 [ 19252 ] {9588abc5-8caa-4b8c-8b27-dba583d646bf} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:52014) (comment: 01542_dictionary_load_exception_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:13.522598 [ 19252 ] {9588abc5-8caa-4b8c-8b27-dba583d646bf} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:13.530256 [ 20380 ] {2af16705-ec59-4008-96db-b9b0e258a4ea} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:51992) (comment: 01542_dictionary_load_exception_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:13.536041 [ 20380 ] {2af16705-ec59-4008-96db-b9b0e258a4ea} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:13.547178 [ 20849 ] {77592ac8-140a-4be4-a70c-589a25129b85} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:52016) (comment: 01542_dictionary_load_exception_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:13.558930 [ 20849 ] {77592ac8-140a-4be4-a70c-589a25129b85} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:13.579885 [ 20882 ] {268ab25a-5a7c-49b2-8ee5-cc841deae1b8} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:52040) (comment: 01542_dictionary_load_exception_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:13.582111 [ 20882 ] {268ab25a-5a7c-49b2-8ee5-cc841deae1b8} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:13.582196 [ 20345 ] {1096dfe6-8646-4636-8e4b-a728109e34f5} executeQuery: Code: 42. DB::Exception: Number of arguments for function IPv6StringToNum doesn't match: passed 2, should be 1: In scope SELECT IPv6StringToNum(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT IPv6StringToNum(NULL, NULL);) 2025.09.09 15:07:13.588145 [ 20345 ] {1096dfe6-8646-4636-8e4b-a728109e34f5} TCPHandler: Code: 42. DB::Exception: Number of arguments for function IPv6StringToNum doesn't match: passed 2, should be 1: In scope SELECT IPv6StringToNum(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:07:13.594496 [ 3612 ] {da5d127f-c1c4-4ad0-87bb-46c1a96d7a47} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:52028) (comment: 01542_dictionary_load_exception_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:13.595809 [ 20881 ] {030e1464-dcbd-4029-bec8-0d568c14f8a0} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:52032) (comment: 01542_dictionary_load_exception_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:13.602330 [ 3612 ] {da5d127f-c1c4-4ad0-87bb-46c1a96d7a47} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:13.603625 [ 3722 ] {223c1305-6b57-48c8-b626-0baeeca63170} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:52004) (comment: 01542_dictionary_load_exception_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:13.610313 [ 20881 ] {030e1464-dcbd-4029-bec8-0d568c14f8a0} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:13.610388 [ 3722 ] {223c1305-6b57-48c8-b626-0baeeca63170} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:13.617481 [ 20397 ] {56c9f388-b31f-46bd-aa6e-0d13b819932a} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:52052) (comment: 01542_dictionary_load_exception_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:13.617707 [ 20338 ] {84d78154-99b7-4ee4-925d-53c436491f42} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:52044) (comment: 01542_dictionary_load_exception_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:13.627855 [ 20343 ] {e3cbdbb9-47c7-4a61-9cd2-f33af9fe4787} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:52060) (comment: 01542_dictionary_load_exception_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:13.638331 [ 20338 ] {84d78154-99b7-4ee4-925d-53c436491f42} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:13.643046 [ 20397 ] {56c9f388-b31f-46bd-aa6e-0d13b819932a} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:13.643069 [ 3181 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:07:13.659589 [ 20343 ] {e3cbdbb9-47c7-4a61-9cd2-f33af9fe4787} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:13.660780 [ 3141 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:07:13.661981 [ 3165 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:07:13.680444 [ 20345 ] {667d12cc-25a3-4b3c-a61d-6dc78d1a4678} executeQuery: Code: 42. DB::Exception: Number of arguments for function IPv6StringToNumOrDefault doesn't match: passed 2, should be 1: In scope SELECT IPv6StringToNumOrDefault(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT IPv6StringToNumOrDefault(NULL, NULL);) 2025.09.09 15:07:13.683042 [ 20345 ] {667d12cc-25a3-4b3c-a61d-6dc78d1a4678} TCPHandler: Code: 42. DB::Exception: Number of arguments for function IPv6StringToNumOrDefault doesn't match: passed 2, should be 1: In scope SELECT IPv6StringToNumOrDefault(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:07:14.024270 [ 20345 ] {637dc373-66ce-4709-802d-01f942ca014f} executeQuery: Code: 42. DB::Exception: Number of arguments for function IPv6StringToNumOrNull doesn't match: passed 2, should be 1: In scope SELECT IPv6StringToNumOrNull(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT IPv6StringToNumOrNull(NULL, NULL);) 2025.09.09 15:07:14.054854 [ 20345 ] {637dc373-66ce-4709-802d-01f942ca014f} TCPHandler: Code: 42. DB::Exception: Number of arguments for function IPv6StringToNumOrNull doesn't match: passed 2, should be 1: In scope SELECT IPv6StringToNumOrNull(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:07:14.181745 [ 20345 ] {f60b9068-839e-46f1-a861-b579f1410fba} executeQuery: Code: 42. DB::Exception: Number of arguments for function JSONAllPaths doesn't match: passed 2, should be 1: In scope SELECT JSONAllPaths(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT JSONAllPaths(NULL, NULL);) 2025.09.09 15:07:14.188269 [ 20345 ] {f60b9068-839e-46f1-a861-b579f1410fba} TCPHandler: Code: 42. DB::Exception: Number of arguments for function JSONAllPaths doesn't match: passed 2, should be 1: In scope SELECT JSONAllPaths(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:07:14.247020 [ 20345 ] {e686e6b4-a0e1-463a-a051-5fda1dc24854} executeQuery: Code: 42. DB::Exception: Number of arguments for function JSONAllPathsWithTypes doesn't match: passed 2, should be 1: In scope SELECT JSONAllPathsWithTypes(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT JSONAllPathsWithTypes(NULL, NULL);) 2025.09.09 15:07:14.251738 [ 20345 ] {e686e6b4-a0e1-463a-a051-5fda1dc24854} TCPHandler: Code: 42. DB::Exception: Number of arguments for function JSONAllPathsWithTypes doesn't match: passed 2, should be 1: In scope SELECT JSONAllPathsWithTypes(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:07:14.260567 [ 3722 ] {c449fb67-2ce4-498d-afc9-f6afcc61f6c0} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:52070) (comment: 01542_dictionary_load_exception_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:14.271348 [ 3161 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:07:14.271551 [ 3722 ] {c449fb67-2ce4-498d-afc9-f6afcc61f6c0} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:14.401404 [ 3612 ] {0eb837bf-e098-4cc2-9831-9e0e89979044} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:52092) (comment: 01542_dictionary_load_exception_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:14.407526 [ 3612 ] {0eb837bf-e098-4cc2-9831-9e0e89979044} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:14.435571 [ 19252 ] {f5b294f5-f41e-412d-873c-25822f9c80c8} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:52074) (comment: 01542_dictionary_load_exception_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:14.451816 [ 20849 ] {3274675a-cd82-46a4-bed1-80e22d62d134} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:52076) (comment: 01542_dictionary_load_exception_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:14.461179 [ 20345 ] {654ceec0-3c66-4a29-814b-eed26adb2b06} executeQuery: Code: 42. DB::Exception: Number of arguments for function JSONArrayLength doesn't match: passed 2, should be 1: In scope SELECT JSONArrayLength(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT JSONArrayLength(NULL, NULL);) 2025.09.09 15:07:14.475399 [ 20849 ] {3274675a-cd82-46a4-bed1-80e22d62d134} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:14.480541 [ 20345 ] {654ceec0-3c66-4a29-814b-eed26adb2b06} TCPHandler: Code: 42. DB::Exception: Number of arguments for function JSONArrayLength doesn't match: passed 2, should be 1: In scope SELECT JSONArrayLength(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:07:14.499995 [ 19252 ] {f5b294f5-f41e-412d-873c-25822f9c80c8} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:14.628702 [ 20345 ] {b721ec11-a989-4200-abd9-bf4077b3cd7b} executeQuery: Code: 42. DB::Exception: Number of arguments for function JSONDynamicPaths doesn't match: passed 2, should be 1: In scope SELECT JSONDynamicPaths(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT JSONDynamicPaths(NULL, NULL);) 2025.09.09 15:07:14.656119 [ 3186 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:07:14.667097 [ 20345 ] {b721ec11-a989-4200-abd9-bf4077b3cd7b} TCPHandler: Code: 42. DB::Exception: Number of arguments for function JSONDynamicPaths doesn't match: passed 2, should be 1: In scope SELECT JSONDynamicPaths(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:07:14.671675 [ 3182 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:07:14.679352 [ 3197 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:07:14.724477 [ 20884 ] {03a7ebfd-cbfe-422a-91a3-1ce881a3398f} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:52084) (comment: 01542_dictionary_load_exception_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:14.734602 [ 20884 ] {03a7ebfd-cbfe-422a-91a3-1ce881a3398f} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:14.741661 [ 20343 ] {02897218-b5b7-47ac-9c3f-2f1fdc5dcb5e} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:52130) (comment: 01542_dictionary_load_exception_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:14.743693 [ 20343 ] {02897218-b5b7-47ac-9c3f-2f1fdc5dcb5e} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:14.756526 [ 20350 ] {e29cd7fa-ab19-46cc-9cea-ccb5710faed9} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:52140) (comment: 01542_dictionary_load_exception_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:14.757424 [ 20351 ] {11c60346-f441-435f-a363-6c524b858886} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:52148) (comment: 01542_dictionary_load_exception_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:14.764250 [ 20350 ] {e29cd7fa-ab19-46cc-9cea-ccb5710faed9} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:14.764911 [ 20351 ] {11c60346-f441-435f-a363-6c524b858886} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:14.768856 [ 20881 ] {4b845102-8227-422a-bb4f-0919de85fb29} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:52098) (comment: 01542_dictionary_load_exception_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:14.779043 [ 20881 ] {4b845102-8227-422a-bb4f-0919de85fb29} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:14.790403 [ 20397 ] {43170f53-16ea-4e44-b776-4db86f33c5ae} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:52128) (comment: 01542_dictionary_load_exception_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:14.798707 [ 20397 ] {43170f53-16ea-4e44-b776-4db86f33c5ae} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:14.812184 [ 20882 ] {5d501a9a-9ec8-4bc7-8229-a46f507ef84f} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:52112) (comment: 01542_dictionary_load_exception_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:14.826912 [ 20338 ] {fe9987ba-16d4-488c-8566-8d7de9985f33} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:52122) (comment: 01542_dictionary_load_exception_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:14.830856 [ 20882 ] {5d501a9a-9ec8-4bc7-8229-a46f507ef84f} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:14.833147 [ 20338 ] {fe9987ba-16d4-488c-8566-8d7de9985f33} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:14.856935 [ 20345 ] {9c416369-d49d-4c51-b090-4932829d60bd} executeQuery: Code: 42. DB::Exception: Number of arguments for function JSONDynamicPathsWithTypes doesn't match: passed 2, should be 1: In scope SELECT JSONDynamicPathsWithTypes(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT JSONDynamicPathsWithTypes(NULL, NULL);) 2025.09.09 15:07:14.931900 [ 20345 ] {9c416369-d49d-4c51-b090-4932829d60bd} TCPHandler: Code: 42. DB::Exception: Number of arguments for function JSONDynamicPathsWithTypes doesn't match: passed 2, should be 1: In scope SELECT JSONDynamicPathsWithTypes(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:07:15.151456 [ 20345 ] {7fc6ad2e-6dfd-4097-9383-e467ba1e5cdd} executeQuery: Code: 44. DB::Exception: The last argument of function JSONExtract should be a constant string specifying the return data type, illegal value: NULL: In scope SELECT JSONExtract(NULL, NULL). (ILLEGAL_COLUMN) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT JSONExtract(NULL, NULL);) 2025.09.09 15:07:15.162389 [ 20345 ] {7fc6ad2e-6dfd-4097-9383-e467ba1e5cdd} TCPHandler: Code: 44. DB::Exception: The last argument of function JSONExtract should be a constant string specifying the return data type, illegal value: NULL: In scope SELECT JSONExtract(NULL, NULL). (ILLEGAL_COLUMN) 2025.09.09 15:07:15.273271 [ 3212 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:07:15.326917 [ 3722 ] {69a8b23a-4461-4184-8e05-21a2179cd24a} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:52156) (comment: 01542_dictionary_load_exception_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:15.339105 [ 3722 ] {69a8b23a-4461-4184-8e05-21a2179cd24a} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:15.340647 [ 19252 ] {f797285e-8775-41a3-a265-1e2051e1323b} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:52160) (comment: 01542_dictionary_load_exception_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:15.350354 [ 19252 ] {f797285e-8775-41a3-a265-1e2051e1323b} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:15.466566 [ 20884 ] {7a9e5aad-391c-497e-b0e1-f8beefc84e49} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:52170) (comment: 01542_dictionary_load_exception_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:15.476034 [ 20884 ] {7a9e5aad-391c-497e-b0e1-f8beefc84e49} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:15.485392 [ 3612 ] {afc7eeae-0ef1-4753-9b95-a1442748dd73} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:52186) (comment: 01542_dictionary_load_exception_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:15.493672 [ 20849 ] {0876b47e-fd24-4181-9f94-6d881dc55e0c} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:52168) (comment: 01542_dictionary_load_exception_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:15.502347 [ 20849 ] {0876b47e-fd24-4181-9f94-6d881dc55e0c} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:15.519200 [ 3612 ] {afc7eeae-0ef1-4753-9b95-a1442748dd73} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:15.658889 [ 3219 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:07:15.674622 [ 3241 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:07:15.681759 [ 3229 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:07:15.737345 [ 20397 ] {a2a90736-8ce3-4b97-bc93-70ca0f48bfd1} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:52222) (comment: 01542_dictionary_load_exception_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:15.739217 [ 20397 ] {a2a90736-8ce3-4b97-bc93-70ca0f48bfd1} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:15.758103 [ 20882 ] {df91908f-ecf1-4d4a-be16-8dca9800ef6a} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:52202) (comment: 01542_dictionary_load_exception_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:15.770246 [ 20882 ] {df91908f-ecf1-4d4a-be16-8dca9800ef6a} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:15.774754 [ 20343 ] {8f63d1c1-2b6c-4f20-a91f-097ceae4a912} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:52230) (comment: 01542_dictionary_load_exception_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:15.775385 [ 20881 ] {10974c0d-6a08-4ce0-9848-36f988d5e1da} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:52190) (comment: 01542_dictionary_load_exception_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:15.778262 [ 20881 ] {10974c0d-6a08-4ce0-9848-36f988d5e1da} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:15.781717 [ 20343 ] {8f63d1c1-2b6c-4f20-a91f-097ceae4a912} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:15.797061 [ 20350 ] {bee78c57-6874-4489-a061-97f3bc553525} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:52234) (comment: 01542_dictionary_load_exception_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:15.797939 [ 20338 ] {229a5935-0c39-49ab-8306-0afe0a7f4a7e} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:52216) (comment: 01542_dictionary_load_exception_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:15.805083 [ 20338 ] {229a5935-0c39-49ab-8306-0afe0a7f4a7e} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:15.805372 [ 20351 ] {e2e14dc0-6bca-46eb-9791-2e4c0683233c} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:52248) (comment: 01542_dictionary_load_exception_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:15.812597 [ 20351 ] {e2e14dc0-6bca-46eb-9791-2e4c0683233c} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:15.874502 [ 20350 ] {bee78c57-6874-4489-a061-97f3bc553525} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:16.214850 [ 20355 ] {2770dd08-37c7-4481-a17f-f17bcf11130a} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:52262) (comment: 01542_dictionary_load_exception_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:16.217988 [ 20355 ] {2770dd08-37c7-4481-a17f-f17bcf11130a} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:16.256912 [ 20353 ] {c22add13-1e90-47ec-83e6-1934d800af0b} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:52252) (comment: 01542_dictionary_load_exception_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:16.278308 [ 20353 ] {c22add13-1e90-47ec-83e6-1934d800af0b} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:16.279046 [ 3239 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:07:16.290212 [ 20351 ] {de71c5f3-8009-497b-9014-67b13da724c2} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:52266) (comment: 01542_dictionary_load_exception_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:16.299799 [ 20351 ] {de71c5f3-8009-497b-9014-67b13da724c2} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:16.308572 [ 20350 ] {dc10797d-cba1-4478-849c-8647f1072b27} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:52280) (comment: 01542_dictionary_load_exception_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:16.310769 [ 20350 ] {dc10797d-cba1-4478-849c-8647f1072b27} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:16.393884 [ 20379 ] {e30903f4-9a35-4754-a1d6-688b4aad95c9} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:52288) (comment: 01542_dictionary_load_exception_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:16.409032 [ 20379 ] {e30903f4-9a35-4754-a1d6-688b4aad95c9} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:16.449597 [ 20345 ] {99c15a7d-c27b-4003-b23e-774ba127be68} executeQuery: Code: 44. DB::Exception: The last argument of function JSONExtractKeysAndValues should be a constant string specifying the values' data type, illegal value: NULL: In scope SELECT JSONExtractKeysAndValues(NULL, NULL). (ILLEGAL_COLUMN) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT JSONExtractKeysAndValues(NULL, NULL);) 2025.09.09 15:07:16.453383 [ 20345 ] {99c15a7d-c27b-4003-b23e-774ba127be68} TCPHandler: Code: 44. DB::Exception: The last argument of function JSONExtractKeysAndValues should be a constant string specifying the values' data type, illegal value: NULL: In scope SELECT JSONExtractKeysAndValues(NULL, NULL). (ILLEGAL_COLUMN) 2025.09.09 15:07:16.625103 [ 20355 ] {1fe1811d-05c5-4de1-844f-b06211f10737} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=790, jobs=741). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:52298) (comment: 01542_dictionary_load_exception_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af872f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af7b2d1 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af7c3f3 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d36920d 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000002d369e5f 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processOrdinaryQuery() @ 0x000000002d18af7b 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d17644a 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 15. asan_thread_start(void*) @ 0x000000000aa43059 16. ? @ 0x00007f35aab92ac3 17. ? @ 0x00007f35aac24850 2025.09.09 15:07:16.638586 [ 20355 ] {1fe1811d-05c5-4de1-844f-b06211f10737} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=790, 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af872f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af7b2d1 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af7c3f3 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d36920d 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000002d369e5f 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processOrdinaryQuery() @ 0x000000002d18af7b 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d17644a 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 15. asan_thread_start(void*) @ 0x000000000aa43059 16. ? @ 0x00007f35aab92ac3 17. ? @ 0x00007f35aac24850 2025.09.09 15:07:16.644978 [ 20353 ] {26b7b91e-ed0f-4902-94f5-3d31226d0709} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:52310) (comment: 01542_dictionary_load_exception_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:16.647000 [ 20380 ] {ba1c5161-6f75-4841-8bec-f211775167b8} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:52326) (comment: 01542_dictionary_load_exception_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:16.649781 [ 20380 ] {ba1c5161-6f75-4841-8bec-f211775167b8} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:16.654348 [ 20353 ] {26b7b91e-ed0f-4902-94f5-3d31226d0709} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:16.660850 [ 2767 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:07:16.663336 [ 19252 ] {682de1fb-a70b-4426-96ab-2d7cd663f28e} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:52356) (comment: 01542_dictionary_load_exception_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:16.670433 [ 19252 ] {682de1fb-a70b-4426-96ab-2d7cd663f28e} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:16.676403 [ 3159 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:07:16.692334 [ 2765 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:07:16.695880 [ 3722 ] {078496d0-db3a-49a4-a3b3-5a2970d387e4} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:52340) (comment: 01542_dictionary_load_exception_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:16.697719 [ 3722 ] {078496d0-db3a-49a4-a3b3-5a2970d387e4} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:16.701877 [ 20351 ] {66b54c4e-0479-4ae9-bf6a-72c7bb19c199} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:52362) (comment: 01542_dictionary_load_exception_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:16.710434 [ 20351 ] {66b54c4e-0479-4ae9-bf6a-72c7bb19c199} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:16.721887 [ 20350 ] {f28cbbd4-c2a6-4c99-a7c0-e3b50986fb80} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:52378) (comment: 01542_dictionary_load_exception_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:16.730020 [ 20350 ] {f28cbbd4-c2a6-4c99-a7c0-e3b50986fb80} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:17.087934 [ 20355 ] {e0f0df9d-50b7-4db0-adf8-0a25599f7dc8} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:52412) (comment: 01542_dictionary_load_exception_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:17.094275 [ 20355 ] {e0f0df9d-50b7-4db0-adf8-0a25599f7dc8} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:17.176739 [ 20351 ] {cd69fb94-3022-438a-ae03-8f14e2824d7c} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:52394) (comment: 01542_dictionary_load_exception_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:17.186654 [ 20353 ] {e2d03e42-c0ae-4735-83e5-729d81be3a77} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:52410) (comment: 01542_dictionary_load_exception_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:17.192943 [ 20353 ] {e2d03e42-c0ae-4735-83e5-729d81be3a77} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:17.194095 [ 20351 ] {cd69fb94-3022-438a-ae03-8f14e2824d7c} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:17.207622 [ 20379 ] {11059a2b-b734-4bc8-be94-6ad239b73cdd} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:52422) (comment: 01542_dictionary_load_exception_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:17.221737 [ 20379 ] {11059a2b-b734-4bc8-be94-6ad239b73cdd} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:17.280987 [ 2768 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:07:17.297954 [ 20350 ] {ceaaa747-96f5-44aa-a97d-a3773b89fdae} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:52398) (comment: 01542_dictionary_load_exception_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:17.307809 [ 20350 ] {ceaaa747-96f5-44aa-a97d-a3773b89fdae} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:17.367229 [ 20380 ] {e0c7ece0-d121-4a4a-b016-e393f97431eb} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:52428) (comment: 01542_dictionary_load_exception_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:17.374230 [ 20380 ] {e0c7ece0-d121-4a4a-b016-e393f97431eb} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:17.432244 [ 20355 ] {1e7516d7-a5f2-4514-a410-28a636c0dc66} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:52442) (comment: 01542_dictionary_load_exception_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:17.432768 [ 20849 ] {bd4cb3ab-f9c3-4975-b46d-50e593546077} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:52462) (comment: 01542_dictionary_load_exception_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:17.434054 [ 20355 ] {1e7516d7-a5f2-4514-a410-28a636c0dc66} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:17.446279 [ 20849 ] {bd4cb3ab-f9c3-4975-b46d-50e593546077} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:17.474546 [ 3722 ] {5afc6dd6-d3c2-4a8c-b57c-2fd1259f15aa} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:52458) (comment: 01542_dictionary_load_exception_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:17.477891 [ 20351 ] {dd0e8e21-090a-441c-bff8-e6f05a3c1938} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:52478) (comment: 01542_dictionary_load_exception_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:17.478081 [ 19252 ] {913bf050-acc2-401f-b58e-efcbbf12b805} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:52460) (comment: 01542_dictionary_load_exception_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:17.482319 [ 3722 ] {5afc6dd6-d3c2-4a8c-b57c-2fd1259f15aa} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:17.484286 [ 20351 ] {dd0e8e21-090a-441c-bff8-e6f05a3c1938} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:17.518299 [ 19252 ] {913bf050-acc2-401f-b58e-efcbbf12b805} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:17.663846 [ 2732 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:07:17.677988 [ 2745 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:07:17.695291 [ 2748 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:07:17.714698 [ 20353 ] {958b5ba5-15d5-445a-8d99-c08522b30c54} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:52494) (comment: 01542_dictionary_load_exception_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:17.728845 [ 20353 ] {958b5ba5-15d5-445a-8d99-c08522b30c54} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:17.919159 [ 20350 ] {ff276dae-fae9-4c89-9101-48567f5148e0} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:52498) (comment: 01542_dictionary_load_exception_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:17.922475 [ 20350 ] {ff276dae-fae9-4c89-9101-48567f5148e0} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:18.045548 [ 20379 ] {4f3fb230-39ba-4bb3-aa00-d06418baa316} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:52512) (comment: 01542_dictionary_load_exception_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:18.048246 [ 20379 ] {4f3fb230-39ba-4bb3-aa00-d06418baa316} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:18.065281 [ 20351 ] {28ccb10b-6865-4c07-bbe2-3ccbd7148a89} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:52500) (comment: 01542_dictionary_load_exception_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:18.067163 [ 20355 ] {7fa29a14-8861-44f2-ba0f-2d168532b1ea} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:52506) (comment: 01542_dictionary_load_exception_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:18.081677 [ 20355 ] {7fa29a14-8861-44f2-ba0f-2d168532b1ea} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:18.082228 [ 20351 ] {28ccb10b-6865-4c07-bbe2-3ccbd7148a89} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:18.111248 [ 20353 ] {4b7ddf89-1d8b-4182-acec-9a5d4b089c1e} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:52516) (comment: 01542_dictionary_load_exception_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:18.118344 [ 20353 ] {4b7ddf89-1d8b-4182-acec-9a5d4b089c1e} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:18.125617 [ 20380 ] {9a9069e5-6a73-40ca-9903-c6d1972f8196} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:52526) (comment: 01542_dictionary_load_exception_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:18.130384 [ 20380 ] {9a9069e5-6a73-40ca-9903-c6d1972f8196} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:18.224680 [ 19252 ] {c5011b58-24a1-4f6f-b9eb-ba5693b66d46} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:40704) (comment: 01542_dictionary_load_exception_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:18.238123 [ 19252 ] {c5011b58-24a1-4f6f-b9eb-ba5693b66d46} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:18.282597 [ 2755 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:07:18.288924 [ 3722 ] {750f0155-a32b-4768-ae7e-7c85a4262a57} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:52528) (comment: 01542_dictionary_load_exception_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:18.383115 [ 20849 ] {950b3a6c-a953-4046-b9b0-86a0b06c2c73} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:40718) (comment: 01542_dictionary_load_exception_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:18.386383 [ 20849 ] {950b3a6c-a953-4046-b9b0-86a0b06c2c73} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:18.391764 [ 20884 ] {a93d0ce8-903e-44ff-81a0-4f709e174d6d} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:40722) (comment: 01542_dictionary_load_exception_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:18.393501 [ 20884 ] {a93d0ce8-903e-44ff-81a0-4f709e174d6d} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:18.427960 [ 3612 ] {5395f331-b26c-4038-a349-bb17d2638424} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:40724) (comment: 01542_dictionary_load_exception_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:18.442322 [ 3722 ] {750f0155-a32b-4768-ae7e-7c85a4262a57} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:18.465338 [ 20173 ] {} test_0473czib.mt (37fd3cf2-879f-4934-ac8d-662471988a31): dropAllData: got exception removing parts from disk, removing successfully removed parts from memory. 2025.09.09 15:07:18.482763 [ 20173 ] {} DatabaseCatalog: Cannot drop table test_0473czib.mt (37fd3cf2-879f-4934-ac8d-662471988a31). Will retry later.: 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af819ed 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80746 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000263a174e 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002c47c445 8. ./contrib/llvm-project/libcxx/include/vector:547: DB::MergeTreeData::clearPartsFromFilesystem(std::vector, std::allocator>> const&, bool, std::unordered_set, std::equal_to, std::allocator>*) @ 0x000000002c47a78e 9. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::dropAllData() @ 0x000000002c4862d9 10. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::dropTableFinally(DB::DatabaseCatalog::TableMarkedAsDropped const&) @ 0x00000000286c7c77 11. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: void std::__function::__policy_invoker::__call_impl, std::allocator>>)::$_0, void ()>>(std::__function::__policy_storage const*) @ 0x00000000286d9744 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000263a3ea5 13. ./contrib/llvm-project/libcxx/include/future:0: std::packaged_task::operator()() @ 0x000000001bba33ac 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7eaf0 15. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001af8a79f 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 18. asan_thread_start(void*) @ 0x000000000aa43059 19. ? @ 0x00007f35aab92ac3 20. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:07:18.554858 [ 3612 ] {5395f331-b26c-4038-a349-bb17d2638424} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:18.600803 [ 20345 ] {bd5fe622-5870-4cf9-b01d-0aa0e9cf4e59} executeQuery: Code: 42. DB::Exception: Number of arguments for function JSONSharedDataPaths doesn't match: passed 2, should be 1: In scope SELECT JSONSharedDataPaths(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT JSONSharedDataPaths(NULL, NULL);) 2025.09.09 15:07:18.622239 [ 20345 ] {bd5fe622-5870-4cf9-b01d-0aa0e9cf4e59} TCPHandler: Code: 42. DB::Exception: Number of arguments for function JSONSharedDataPaths doesn't match: passed 2, should be 1: In scope SELECT JSONSharedDataPaths(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:07:18.665854 [ 2800 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:07:18.679670 [ 2773 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:07:18.697049 [ 2776 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:07:18.703926 [ 20881 ] {5180fb5c-331e-4e64-a255-2aee014c8c1f} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:40732) (comment: 01542_dictionary_load_exception_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:18.710336 [ 20881 ] {5180fb5c-331e-4e64-a255-2aee014c8c1f} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:18.791397 [ 20345 ] {7e43de9d-a1a2-49b5-904a-e91aa89f6752} executeQuery: Code: 42. DB::Exception: Number of arguments for function JSONSharedDataPathsWithTypes doesn't match: passed 2, should be 1: In scope SELECT JSONSharedDataPathsWithTypes(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT JSONSharedDataPathsWithTypes(NULL, NULL);) 2025.09.09 15:07:18.795879 [ 20345 ] {7e43de9d-a1a2-49b5-904a-e91aa89f6752} TCPHandler: Code: 42. DB::Exception: Number of arguments for function JSONSharedDataPathsWithTypes doesn't match: passed 2, should be 1: In scope SELECT JSONSharedDataPathsWithTypes(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:07:18.812476 [ 19252 ] {2fe45858-a13e-4e42-a095-628baceec70a} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:40736) (comment: 01542_dictionary_load_exception_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:18.831932 [ 19252 ] {2fe45858-a13e-4e42-a095-628baceec70a} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:18.836899 [ 3722 ] {f8521e7b-a104-4a6a-ae97-e8c12afe4d30} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:40748) (comment: 01542_dictionary_load_exception_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:18.847005 [ 3722 ] {f8521e7b-a104-4a6a-ae97-e8c12afe4d30} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:18.904797 [ 20884 ] {20027693-5b0f-4309-aa9b-dd038f7b4b34} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:40762) (comment: 01542_dictionary_load_exception_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:18.909530 [ 3612 ] {7af521f9-dc41-4b22-812b-f8591b29e9cd} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:40770) (comment: 01542_dictionary_load_exception_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:18.916835 [ 3612 ] {7af521f9-dc41-4b22-812b-f8591b29e9cd} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:18.978486 [ 20849 ] {11968971-0f00-4ab0-bd69-d3cf97388c79} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:40750) (comment: 01542_dictionary_load_exception_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:18.990442 [ 20884 ] {20027693-5b0f-4309-aa9b-dd038f7b4b34} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:19.011101 [ 20882 ] {bbbef914-0430-436e-b319-d8b8dfa3d13c} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:40780) (comment: 01542_dictionary_load_exception_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:19.027054 [ 20849 ] {11968971-0f00-4ab0-bd69-d3cf97388c79} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:19.036723 [ 20882 ] {bbbef914-0430-436e-b319-d8b8dfa3d13c} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:19.145505 [ 20345 ] {5b9f6c53-f899-4bb7-b44f-43c71c930aba} executeQuery: Code: 42. DB::Exception: Number of arguments for function JSONArrayLength doesn't match: passed 2, should be 1: In scope SELECT JSON_ARRAY_LENGTH(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT JSON_ARRAY_LENGTH(NULL, NULL);) 2025.09.09 15:07:19.172529 [ 20345 ] {5b9f6c53-f899-4bb7-b44f-43c71c930aba} TCPHandler: Code: 42. DB::Exception: Number of arguments for function JSONArrayLength doesn't match: passed 2, should be 1: In scope SELECT JSON_ARRAY_LENGTH(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:07:19.223842 [ 20338 ] {5b605541-8489-4c6a-9a1a-326164bf40e7} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:40782) (comment: 01542_dictionary_load_exception_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:19.230661 [ 20338 ] {5b605541-8489-4c6a-9a1a-326164bf40e7} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:19.287007 [ 2787 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:07:19.298695 [ 19252 ] {8568588c-abe0-4222-a58d-2d335a234498} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:40816) (comment: 01542_dictionary_load_exception_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:19.299215 [ 20881 ] {4210d56c-b6b7-42be-b55b-b1f19c4750e6} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:40798) (comment: 01542_dictionary_load_exception_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:19.300808 [ 19252 ] {8568588c-abe0-4222-a58d-2d335a234498} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:19.300870 [ 20881 ] {4210d56c-b6b7-42be-b55b-b1f19c4750e6} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:19.326219 [ 3722 ] {a12f6f79-ae26-405c-91ff-1ede9c6129b4} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:40806) (comment: 01542_dictionary_load_exception_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:19.368437 [ 3722 ] {a12f6f79-ae26-405c-91ff-1ede9c6129b4} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:19.536212 [ 20849 ] {70bc231d-de31-432b-8280-68b23aaecca8} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:40838) (comment: 01542_dictionary_load_exception_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:19.542427 [ 20849 ] {70bc231d-de31-432b-8280-68b23aaecca8} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:19.545325 [ 3065 ] {} test_3.part_header_r1 (ReplicatedMergeTreeCleanupThread): void DB::ReplicatedMergeTreeCleanupThread::run(): Code: 999. Coordination::Exception: Coordination error: Operation timeout, path /clickhouse/tables/00814_replicated_minimalistic_part_header_zookeeper_test_3/test_00814/part_header/s1/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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: Coordination::Exception::Exception(Coordination::Error, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x00000000264863d9 4. ./src/Common/ZooKeeper/IKeeper.h:501: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x00000000264847c3 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:373: zkutil::ZooKeeper::tryGetChildrenWatch(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000002e5ea628 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:346: zkutil::ZooKeeper::tryGetChildren(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr const&, Coordination::ListRequestType) @ 0x000000002e5e9d09 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:514: DB::ReplicatedMergeTreeCleanupThread::getBlocksSortedByTime(String const&, zkutil::ZooKeeper&, std::vector>&, std::map, std::less, std::allocator>>>&) @ 0x000000002ca25d67 8. ./contrib/llvm-project/libcxx/include/vector:553: DB::ReplicatedMergeTreeCleanupThread::clearOldBlocks(String const&, unsigned long, unsigned long, std::map, std::less, std::allocator>>>&) @ 0x000000002ca1d797 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x000000002ca153d0 10. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:50: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x000000002ca13666 11. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 13. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 16. asan_thread_start(void*) @ 0x000000000aa43059 17. ? @ 0x00007f35aab92ac3 18. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:07:19.549997 [ 2809 ] {} test_3.part_log_profile_events_r2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.09.09 15:07:19.555528 [ 2803 ] {} test_3.part_header_r2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.09.09 15:07:19.556276 [ 2802 ] {} test_3.part_header_r1 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.09.09 15:07:19.557922 [ 2812 ] {} test_3.part_log_profile_events_r1 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.09.09 15:07:19.559085 [ 2808 ] {} test_3.test_03217_merge_replica_2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.09.09 15:07:19.560213 [ 2789 ] {} test_3.src (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.09.09 15:07:19.561540 [ 2791 ] {} test_3.test_03217_merge_replica_1 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.09.09 15:07:19.562531 [ 2814 ] {} test_15.primary_key (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.09.09 15:07:19.563507 [ 2830 ] {} test_1.order_by_all (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.09.09 15:07:19.598474 [ 2754 ] {} test_3.part_log_profile_events_r1 (ReplicatedMergeTreeCleanupThread): void DB::ReplicatedMergeTreeCleanupThread::run(): Code: 999. Coordination::Exception: Coordination error: Connection loss, path /clickhouse/tables/test_3/test_02378/part_log_profile_events/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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: Coordination::Exception::Exception(Coordination::Error, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x00000000264863d9 4. ./src/Common/ZooKeeper/IKeeper.h:501: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x00000000264847c3 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:601: zkutil::ZooKeeper::existsWatch(String const&, Coordination::Stat*, std::function) @ 0x000000002e5f1707 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002e5ebc63 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:203: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x000000002ca16d1a 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x000000002ca15340 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:50: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x000000002ca13666 10. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 12. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 15. asan_thread_start(void*) @ 0x000000000aa43059 16. ? @ 0x00007f35aab92ac3 17. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:07:19.598601 [ 2747 ] {} test_3.test_03217_merge_replica_2 (ReplicatedMergeTreeCleanupThread): void DB::ReplicatedMergeTreeCleanupThread::run(): Code: 999. Coordination::Exception: Coordination error: Connection loss, path /clickhouse/tables/test_3/test_03217_merge_replica/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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: Coordination::Exception::Exception(Coordination::Error, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x00000000264863d9 4. ./src/Common/ZooKeeper/IKeeper.h:501: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x00000000264847c3 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:601: zkutil::ZooKeeper::existsWatch(String const&, Coordination::Stat*, std::function) @ 0x000000002e5f1707 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002e5ebc63 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:203: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x000000002ca16d1a 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x000000002ca15340 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:50: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x000000002ca13666 10. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 12. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 15. asan_thread_start(void*) @ 0x000000000aa43059 16. ? @ 0x00007f35aab92ac3 17. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:07:19.598610 [ 3058 ] {} test_3.part_header_r2 (ReplicatedMergeTreeCleanupThread): void DB::ReplicatedMergeTreeCleanupThread::run(): Code: 999. Coordination::Exception: Coordination error: Operation timeout, path /clickhouse/tables/00814_replicated_minimalistic_part_header_zookeeper_test_3/test_00814/part_header/s1/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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: Coordination::Exception::Exception(Coordination::Error, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x00000000264863d9 4. ./src/Common/ZooKeeper/IKeeper.h:501: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x00000000264847c3 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:601: zkutil::ZooKeeper::existsWatch(String const&, Coordination::Stat*, std::function) @ 0x000000002e5f1707 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002e5ebc63 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:203: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x000000002ca16d1a 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x000000002ca15340 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:50: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x000000002ca13666 10. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 12. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 15. asan_thread_start(void*) @ 0x000000000aa43059 16. ? @ 0x00007f35aab92ac3 17. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:07:19.598711 [ 2811 ] {} test_15.primary_key (ReplicatedMergeTreeCleanupThread): void DB::ReplicatedMergeTreeCleanupThread::run(): Code: 999. Coordination::Exception: Coordination error: Connection loss, path /clickhouse/tables/test_15/test_00215/primary_key/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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: Coordination::Exception::Exception(Coordination::Error, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x00000000264863d9 4. ./src/Common/ZooKeeper/IKeeper.h:501: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x00000000264847c3 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:601: zkutil::ZooKeeper::existsWatch(String const&, Coordination::Stat*, std::function) @ 0x000000002e5f1707 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002e5ebc63 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:203: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x000000002ca16d1a 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x000000002ca15340 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:50: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x000000002ca13666 10. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 12. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 15. asan_thread_start(void*) @ 0x000000000aa43059 16. ? @ 0x00007f35aab92ac3 17. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:07:19.598561 [ 2734 ] {} test_3.test_03217_merge_replica_1 (ReplicatedMergeTreeCleanupThread): void DB::ReplicatedMergeTreeCleanupThread::run(): Code: 999. Coordination::Exception: Coordination error: Connection loss, path /clickhouse/tables/test_3/test_03217_merge_replica/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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: Coordination::Exception::Exception(Coordination::Error, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x00000000264863d9 4. ./src/Common/ZooKeeper/IKeeper.h:501: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x00000000264847c3 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:601: zkutil::ZooKeeper::existsWatch(String const&, Coordination::Stat*, std::function) @ 0x000000002e5f1707 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002e5ebc63 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:203: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x000000002ca16d1a 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x000000002ca15340 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:50: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x000000002ca13666 10. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 12. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 15. asan_thread_start(void*) @ 0x000000000aa43059 16. ? @ 0x00007f35aab92ac3 17. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:07:19.611774 [ 2786 ] {} test_1.order_by_all (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. ./contrib/llvm-project/libcxx/include/string:1499: _ZN12Coordination9ExceptionC2IRA16_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x000000002e65bfe6 3. ./src/Common/ZooKeeper/IKeeper.h:0: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x000000002e6c2259 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1365: Coordination::ZooKeeper::exists(String const&, std::function, std::shared_ptr>) @ 0x000000002e6c8872 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002e5f1235 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002e5f076a 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:598: zkutil::ZooKeeper::existsWatch(String const&, Coordination::Stat*, std::function) @ 0x000000002e5f16a2 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002e5ebc63 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:203: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x000000002ca16d1a 10. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x000000002ca15340 11. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:50: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x000000002ca13666 12. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 14. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:07:19.613006 [ 2806 ] {} test_3.part_header_r1 (ReplicatedMergeTreeCleanupThread): void DB::ReplicatedMergeTreeCleanupThread::run(): Code: 999. Coordination::Exception: Session expired. (KEEPER_EXCEPTION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. ./contrib/llvm-project/libcxx/include/string:1499: _ZN12Coordination9ExceptionC2IRA16_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x000000002e65bfe6 3. ./src/Common/ZooKeeper/IKeeper.h:0: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x000000002e6c2259 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1365: Coordination::ZooKeeper::exists(String const&, std::function, std::shared_ptr>) @ 0x000000002e6c8872 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002e5f1235 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002e5f076a 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:598: zkutil::ZooKeeper::existsWatch(String const&, Coordination::Stat*, std::function) @ 0x000000002e5f16a2 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002e5ebc63 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:203: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x000000002ca16d1a 10. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x000000002ca15340 11. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:50: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x000000002ca13666 12. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 14. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:07:19.641790 [ 20884 ] {d4cb066c-a6be-4a59-8217-f4fb2703ebbd} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:40822) (comment: 01542_dictionary_load_exception_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:19.643883 [ 20884 ] {d4cb066c-a6be-4a59-8217-f4fb2703ebbd} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:19.667773 [ 2807 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:07:19.684057 [ 2810 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:07:19.699230 [ 2822 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:07:19.751335 [ 3612 ] {6e5e0732-1043-4f36-a0d4-970b126541ea} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:40850) (comment: 01542_dictionary_load_exception_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:19.752793 [ 19252 ] {71498d4b-d828-4a1f-af4e-aa32aedd4cdf} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:40846) (comment: 01542_dictionary_load_exception_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:19.766329 [ 3612 ] {6e5e0732-1043-4f36-a0d4-970b126541ea} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:19.766834 [ 19252 ] {71498d4b-d828-4a1f-af4e-aa32aedd4cdf} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:19.809991 [ 20881 ] {df47d3e0-29b5-402b-ba62-9a4e57e2a10c} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:40856) (comment: 01542_dictionary_load_exception_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:19.810034 [ 20882 ] {ee0aeeba-e4b0-4812-b687-9b3a719dc40c} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:40880) (comment: 01542_dictionary_load_exception_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:19.818505 [ 20882 ] {ee0aeeba-e4b0-4812-b687-9b3a719dc40c} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:19.818550 [ 20881 ] {df47d3e0-29b5-402b-ba62-9a4e57e2a10c} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:19.824775 [ 3722 ] {8681f90a-d804-4060-9488-96f29434adab} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:40870) (comment: 01542_dictionary_load_exception_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:19.834639 [ 20338 ] {7dd9eb8e-afc8-4811-aba9-02acc58c17fe} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:40892) (comment: 01542_dictionary_load_exception_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:19.844197 [ 20338 ] {7dd9eb8e-afc8-4811-aba9-02acc58c17fe} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:19.867873 [ 3722 ] {8681f90a-d804-4060-9488-96f29434adab} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:20.134230 [ 20849 ] {b1d10631-f23c-4db6-af01-5adc6a13e813} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:40906) (comment: 01542_dictionary_load_exception_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:20.142708 [ 20849 ] {b1d10631-f23c-4db6-af01-5adc6a13e813} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:20.175228 [ 20345 ] {e2f377f2-1851-47d4-bb9e-17ea488d1fba} executeQuery: Code: 42. DB::Exception: Number of arguments for function L1Norm doesn't match: passed 2, should be 1: In scope SELECT L1Norm(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT L1Norm(NULL, NULL);) 2025.09.09 15:07:20.175936 [ 3612 ] {577a8d7c-a5c6-485a-bfbd-59bab974f9cb} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:40922) (comment: 01542_dictionary_load_exception_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:20.184488 [ 3612 ] {577a8d7c-a5c6-485a-bfbd-59bab974f9cb} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:20.203786 [ 20884 ] {90b6a71f-891c-4c52-878a-3a2294d3a676} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:40912) (comment: 01542_dictionary_load_exception_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:20.204127 [ 20345 ] {e2f377f2-1851-47d4-bb9e-17ea488d1fba} TCPHandler: Code: 42. DB::Exception: Number of arguments for function L1Norm doesn't match: passed 2, should be 1: In scope SELECT L1Norm(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:07:20.215674 [ 20884 ] {90b6a71f-891c-4c52-878a-3a2294d3a676} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:20.288434 [ 2843 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:07:20.359752 [ 20345 ] {5d4ff612-11f6-4f08-aed6-336eb6691910} executeQuery: Code: 42. DB::Exception: Number of arguments for function L1Normalize doesn't match: passed 2, should be 1: In scope SELECT L1Normalize(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT L1Normalize(NULL, NULL);) 2025.09.09 15:07:20.373803 [ 20345 ] {5d4ff612-11f6-4f08-aed6-336eb6691910} TCPHandler: Code: 42. DB::Exception: Number of arguments for function L1Normalize doesn't match: passed 2, should be 1: In scope SELECT L1Normalize(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:07:20.398284 [ 19252 ] {ff56878a-b463-4194-b470-f0a55597aa01} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:40928) (comment: 01542_dictionary_load_exception_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:20.410617 [ 19252 ] {ff56878a-b463-4194-b470-f0a55597aa01} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:20.445061 [ 3722 ] {1611d4f5-937a-4738-9635-057ef3df9836} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:40936) (comment: 01542_dictionary_load_exception_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:20.453477 [ 3722 ] {1611d4f5-937a-4738-9635-057ef3df9836} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:20.541711 [ 20849 ] {bf5b19b1-284f-492a-bce8-935611cd16bb} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:40948) (comment: 01542_dictionary_load_exception_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:20.562280 [ 20849 ] {bf5b19b1-284f-492a-bce8-935611cd16bb} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:20.563511 [ 3612 ] {c6cdc88a-e6b5-4f5e-8797-d30c2cc5de69} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:40974) (comment: 01542_dictionary_load_exception_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:20.570390 [ 3612 ] {c6cdc88a-e6b5-4f5e-8797-d30c2cc5de69} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:20.611631 [ 20884 ] {315ea3ed-511b-49a4-88c6-dd05564c2fc6} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:40962) (comment: 01542_dictionary_load_exception_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:20.614529 [ 20884 ] {315ea3ed-511b-49a4-88c6-dd05564c2fc6} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:20.636430 [ 20882 ] {64bcacfd-53c8-4f07-82fc-72eaa8946e04} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:40982) (comment: 01542_dictionary_load_exception_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:20.638415 [ 20882 ] {64bcacfd-53c8-4f07-82fc-72eaa8946e04} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:20.642441 [ 20881 ] {00066d60-8c6f-4cb0-a119-90a32a1e9201} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:40980) (comment: 01542_dictionary_load_exception_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:20.644719 [ 20343 ] {bf1d8672-753c-471a-ae88-98416d56c351} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:41012) (comment: 01542_dictionary_load_exception_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:20.644750 [ 20881 ] {00066d60-8c6f-4cb0-a119-90a32a1e9201} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:20.651600 [ 20343 ] {bf1d8672-753c-471a-ae88-98416d56c351} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:20.663827 [ 20338 ] {f8a031e2-58a0-42e9-885e-72a88e65413e} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:40996) (comment: 01542_dictionary_load_exception_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:20.665621 [ 20338 ] {f8a031e2-58a0-42e9-885e-72a88e65413e} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:20.671438 [ 2914 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:07:20.690767 [ 2885 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:07:20.702469 [ 2904 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:07:20.777158 [ 20345 ] {fc11489b-8ccf-4fb4-ba20-24a71ffc5e7b} executeQuery: Code: 42. DB::Exception: Number of arguments for function L2Norm doesn't match: passed 2, should be 1: In scope SELECT L2Norm(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT L2Norm(NULL, NULL);) 2025.09.09 15:07:20.793189 [ 20345 ] {fc11489b-8ccf-4fb4-ba20-24a71ffc5e7b} TCPHandler: Code: 42. DB::Exception: Number of arguments for function L2Norm doesn't match: passed 2, should be 1: In scope SELECT L2Norm(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:07:20.906127 [ 20345 ] {9a62cadd-07a5-483e-855b-de3dccb7de90} executeQuery: Code: 42. DB::Exception: Number of arguments for function L2Normalize doesn't match: passed 2, should be 1: In scope SELECT L2Normalize(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT L2Normalize(NULL, NULL);) 2025.09.09 15:07:20.912810 [ 20345 ] {9a62cadd-07a5-483e-855b-de3dccb7de90} TCPHandler: Code: 42. DB::Exception: Number of arguments for function L2Normalize doesn't match: passed 2, should be 1: In scope SELECT L2Normalize(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:07:21.034706 [ 3612 ] {b5104041-995d-4fa1-9138-fe9a034eaa44} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:41026) (comment: 01542_dictionary_load_exception_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:21.044026 [ 3612 ] {b5104041-995d-4fa1-9138-fe9a034eaa44} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:21.046836 [ 20882 ] {a7b38e53-d1ee-4bcf-95c5-053a5692f8de} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:41042) (comment: 01542_dictionary_load_exception_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:21.061003 [ 20882 ] {a7b38e53-d1ee-4bcf-95c5-053a5692f8de} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:21.062601 [ 20881 ] {5efe775b-f798-4a39-9891-3fd48f766570} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:41030) (comment: 01542_dictionary_load_exception_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:21.166369 [ 20881 ] {5efe775b-f798-4a39-9891-3fd48f766570} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:21.215104 [ 20345 ] {bc513e07-ab58-4f20-bd92-cbcac0fbb2f6} executeQuery: Code: 42. DB::Exception: Number of arguments for function L2SquaredNorm doesn't match: passed 2, should be 1: In scope SELECT L2SquaredNorm(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT L2SquaredNorm(NULL, NULL);) 2025.09.09 15:07:21.224188 [ 20345 ] {bc513e07-ab58-4f20-bd92-cbcac0fbb2f6} TCPHandler: Code: 42. DB::Exception: Number of arguments for function L2SquaredNorm doesn't match: passed 2, should be 1: In scope SELECT L2SquaredNorm(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:07:21.258514 [ 20343 ] {34878b4d-20f9-42d6-998f-565907db553c} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:41050) (comment: 01542_dictionary_load_exception_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:21.259610 [ 20338 ] {180d0e9b-ad6d-4e3b-b2cf-3b010230c23e} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:41046) (comment: 01542_dictionary_load_exception_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:21.261689 [ 20343 ] {34878b4d-20f9-42d6-998f-565907db553c} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:21.285052 [ 20338 ] {180d0e9b-ad6d-4e3b-b2cf-3b010230c23e} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:21.290077 [ 2943 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:07:21.358538 [ 3612 ] {0385a323-7aa4-4661-a517-b2b905e9a71c} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:41066) (comment: 01542_dictionary_load_exception_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:21.366824 [ 3612 ] {0385a323-7aa4-4661-a517-b2b905e9a71c} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:21.430733 [ 20882 ] {76772184-fd6e-4aeb-928c-d2b261ba8e1f} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:41078) (comment: 01542_dictionary_load_exception_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:21.443318 [ 20882 ] {76772184-fd6e-4aeb-928c-d2b261ba8e1f} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:21.445219 [ 20350 ] {0c830600-2de9-46fa-9443-86a10c3e5b11} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:41090) (comment: 01542_dictionary_load_exception_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:21.466250 [ 20350 ] {0c830600-2de9-46fa-9443-86a10c3e5b11} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:21.473290 [ 20351 ] {d7dd3111-3d33-40a9-b25c-d475109c4702} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:41100) (comment: 01542_dictionary_load_exception_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:21.479572 [ 20351 ] {d7dd3111-3d33-40a9-b25c-d475109c4702} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:21.554507 [ 20881 ] {b046a047-0e4f-4984-b75f-9e386a6e2b62} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:41112) (comment: 01542_dictionary_load_exception_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:21.556033 [ 20881 ] {b046a047-0e4f-4984-b75f-9e386a6e2b62} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:21.564934 [ 20353 ] {00cd1f2d-cc22-495b-94f5-8cf43d3c58a2} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:41124) (comment: 01542_dictionary_load_exception_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:21.571692 [ 20353 ] {00cd1f2d-cc22-495b-94f5-8cf43d3c58a2} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:21.672937 [ 2945 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:07:21.692202 [ 2992 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:07:21.692950 [ 20355 ] {96db3cd3-d59f-480f-b9f5-19be41c7a960} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:41138) (comment: 01542_dictionary_load_exception_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:21.697615 [ 20355 ] {96db3cd3-d59f-480f-b9f5-19be41c7a960} TCPHandler: Can't send logs to client: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::1]:9000 -> [::1]:41138). (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 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&&) @ 0x000000001b0b7a5f 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:169: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000001b0bada2 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:201: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000002cf09bf7 5. ./src/IO/WriteBuffer.h:66: DB::TCPHandler::sendLogData(DB::Block const&) @ 0x000000002d1a9beb 6. ./contrib/llvm-project/libcxx/include/__hash_table:1473: DB::TCPHandler::sendLogs() @ 0x000000002d18db59 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d176902 8. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 12. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 13. asan_thread_start(void*) @ 0x000000000aa43059 14. ? @ 0x00007f35aab92ac3 15. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:07:21.698735 [ 20355 ] {96db3cd3-d59f-480f-b9f5-19be41c7a960} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:21.699933 [ 20355 ] {96db3cd3-d59f-480f-b9f5-19be41c7a960} TCPHandler: Client has gone away. 2025.09.09 15:07:21.707784 [ 2995 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:07:21.760377 [ 20345 ] {dc02b230-cd86-461c-b0ce-92a1c46b7461} executeQuery: Code: 42. DB::Exception: Number of arguments for function LinfNorm doesn't match: passed 2, should be 1: In scope SELECT LinfNorm(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT LinfNorm(NULL, NULL);) 2025.09.09 15:07:21.762700 [ 20345 ] {dc02b230-cd86-461c-b0ce-92a1c46b7461} TCPHandler: Code: 42. DB::Exception: Number of arguments for function LinfNorm doesn't match: passed 2, should be 1: In scope SELECT LinfNorm(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:07:21.953793 [ 20345 ] {7727110c-39ad-42a1-b827-6eedb0135201} executeQuery: Code: 42. DB::Exception: Number of arguments for function LinfNormalize doesn't match: passed 2, should be 1: In scope SELECT LinfNormalize(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT LinfNormalize(NULL, NULL);) 2025.09.09 15:07:21.957143 [ 20345 ] {7727110c-39ad-42a1-b827-6eedb0135201} TCPHandler: Code: 42. DB::Exception: Number of arguments for function LinfNormalize doesn't match: passed 2, should be 1: In scope SELECT LinfNormalize(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:07:22.055842 [ 20345 ] {eb6b1369-cb28-407a-b9c9-9646da9a79ca} executeQuery: Code: 42. DB::Exception: Number of arguments for function LpDistance doesn't match: passed 2, should be 3: In scope SELECT LpDistance(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT LpDistance(NULL, NULL);) 2025.09.09 15:07:22.062820 [ 20345 ] {eb6b1369-cb28-407a-b9c9-9646da9a79ca} TCPHandler: Code: 42. DB::Exception: Number of arguments for function LpDistance doesn't match: passed 2, should be 3: In scope SELECT LpDistance(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:07:22.299014 [ 3039 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:07:22.330355 [ 3612 ] {b80f337f-c956-409b-924d-0d165d22af02} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=0, jobs=0). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:41154) (comment: 01542_dictionary_load_exception_race.sh) (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af80b71 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80746 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000263a174e 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000291f4e6a 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:361: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000291edc97 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x00000000291ebf11 10. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x00000000291eb7ed 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b382fc 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 14. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 19. asan_thread_start(void*) @ 0x000000000aa43059 20. ? @ 0x00007f35aab92ac3 21. ? @ 0x00007f35aac24850 2025.09.09 15:07:22.362326 [ 3612 ] {b80f337f-c956-409b-924d-0d165d22af02} 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af80b71 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80746 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000263a174e 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000291f4e6a 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:361: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000291edc97 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x00000000291ebf11 10. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x00000000291eb7ed 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b382fc 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 14. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 19. asan_thread_start(void*) @ 0x000000000aa43059 20. ? @ 0x00007f35aab92ac3 21. ? @ 0x00007f35aac24850 2025.09.09 15:07:22.443469 [ 20164 ] {} ExternalDictionariesLoader: Could not load external dictionary 'b9456353-118f-4e69-ac1b-88d4f6a6e618', next update is scheduled at 2025-09-09 15:07:32: 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:07:22.677712 [ 20345 ] {81e89819-c069-4721-af50-323821a507d2} executeQuery: Code: 42. DB::Exception: Number of arguments for function MACNumToString doesn't match: passed 2, should be 1: In scope SELECT MACNumToString(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT MACNumToString(NULL, NULL);) 2025.09.09 15:07:22.684669 [ 3048 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:07:22.693903 [ 20345 ] {81e89819-c069-4721-af50-323821a507d2} TCPHandler: Code: 42. DB::Exception: Number of arguments for function MACNumToString doesn't match: passed 2, should be 1: In scope SELECT MACNumToString(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:07:22.694747 [ 3059 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:07:22.710358 [ 3072 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:07:22.777721 [ 20345 ] {a12d2231-7077-4c17-8a4a-6d7999c517af} executeQuery: Code: 42. DB::Exception: Number of arguments for function MACStringToNum doesn't match: passed 2, should be 1: In scope SELECT MACStringToNum(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT MACStringToNum(NULL, NULL);) 2025.09.09 15:07:22.782600 [ 20345 ] {a12d2231-7077-4c17-8a4a-6d7999c517af} TCPHandler: Code: 42. DB::Exception: Number of arguments for function MACStringToNum doesn't match: passed 2, should be 1: In scope SELECT MACStringToNum(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:07:22.884855 [ 20345 ] {f529b246-5e73-4e9d-9650-47d4b5a11f10} executeQuery: Code: 42. DB::Exception: Number of arguments for function MACStringToOUI doesn't match: passed 2, should be 1: In scope SELECT MACStringToOUI(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT MACStringToOUI(NULL, NULL);) 2025.09.09 15:07:22.902156 [ 20345 ] {f529b246-5e73-4e9d-9650-47d4b5a11f10} TCPHandler: Code: 42. DB::Exception: Number of arguments for function MACStringToOUI doesn't match: passed 2, should be 1: In scope SELECT MACStringToOUI(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:07:22.981837 [ 20345 ] {e7fe6bb5-9091-43ea-ab63-95fe892e0ca9} executeQuery: Code: 43. DB::Exception: Arguments of function mapFromArrays must be Array or Map, but Nullable(Nothing) is given: In scope SELECT MAP_FROM_ARRAYS(NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT MAP_FROM_ARRAYS(NULL, NULL);) 2025.09.09 15:07:22.985004 [ 20345 ] {e7fe6bb5-9091-43ea-ab63-95fe892e0ca9} TCPHandler: Code: 43. DB::Exception: Arguments of function mapFromArrays must be Array or Map, but Nullable(Nothing) is given: In scope SELECT MAP_FROM_ARRAYS(NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.09.09 15:07:23.025393 [ 20345 ] {2b426570-93c5-4167-a052-9277ea849663} executeQuery: Code: 42. DB::Exception: Number of arguments for function MD4 doesn't match: passed 2, should be 1: In scope SELECT MD4(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT MD4(NULL, NULL);) 2025.09.09 15:07:23.028578 [ 20345 ] {2b426570-93c5-4167-a052-9277ea849663} TCPHandler: Code: 42. DB::Exception: Number of arguments for function MD4 doesn't match: passed 2, should be 1: In scope SELECT MD4(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:07:23.096295 [ 20345 ] {8a7ebecf-66b0-4599-b11d-285847a4486a} executeQuery: Code: 42. DB::Exception: Number of arguments for function MD5 doesn't match: passed 2, should be 1: In scope SELECT MD5(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT MD5(NULL, NULL);) 2025.09.09 15:07:23.137113 [ 20881 ] {55d76418-1924-4258-92f4-aeeb552871ef} executeQuery: Code: 630. DB::Exception: Cannot drop or rename database_for_dict.table_for_dict (cabf9a66-80e2-4148-8335-3c53187f5a8a), because some tables depend on it: ordinary_db.dict1. (HAVE_DEPENDENT_OBJECTS) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:41170) (comment: 01542_dictionary_load_exception_race.sh) (in query: DROP DATABASE IF EXISTS database_for_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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception, std::__wrap_iter, char>>(int, FormatStringHelperImpl::type, std::type_identity, std::__wrap_iter, char>>::type>, DB::StorageID const&, fmt::v9::join_view, std::__wrap_iter, char>&&) @ 0x00000000286dbc7a 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:1536: DB::DatabaseCatalog::checkTableCanBeRemovedOrRenamedUnlocked(DB::StorageID const&, bool, bool, bool) const @ 0x00000000286cc3da 5. ./contrib/llvm-project/libcxx/include/__mutex_base:100: DB::DatabaseCatalog::checkTableCanBeRemovedOrRenamed(DB::StorageID const&, bool, bool, bool) const @ 0x00000000286cc97f 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x00000000291f0b89 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:454: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x00000000291f510c 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:361: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000291edc97 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x00000000291ebf11 10. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x00000000291eb7ed 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b382fc 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 14. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 19. asan_thread_start(void*) @ 0x000000000aa43059 20. ? @ 0x00007f35aab92ac3 21. ? @ 0x00007f35aac24850 2025.09.09 15:07:23.142612 [ 20881 ] {55d76418-1924-4258-92f4-aeeb552871ef} TCPHandler: Code: 630. DB::Exception: Cannot drop or rename database_for_dict.table_for_dict (cabf9a66-80e2-4148-8335-3c53187f5a8a), because some tables depend on it: ordinary_db.dict1. (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception, std::__wrap_iter, char>>(int, FormatStringHelperImpl::type, std::type_identity, std::__wrap_iter, char>>::type>, DB::StorageID const&, fmt::v9::join_view, std::__wrap_iter, char>&&) @ 0x00000000286dbc7a 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:1536: DB::DatabaseCatalog::checkTableCanBeRemovedOrRenamedUnlocked(DB::StorageID const&, bool, bool, bool) const @ 0x00000000286cc3da 5. ./contrib/llvm-project/libcxx/include/__mutex_base:100: DB::DatabaseCatalog::checkTableCanBeRemovedOrRenamed(DB::StorageID const&, bool, bool, bool) const @ 0x00000000286cc97f 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x00000000291f0b89 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:454: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x00000000291f510c 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:361: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000291edc97 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x00000000291ebf11 10. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x00000000291eb7ed 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b382fc 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 14. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 19. asan_thread_start(void*) @ 0x000000000aa43059 20. ? @ 0x00007f35aab92ac3 21. ? @ 0x00007f35aac24850 2025.09.09 15:07:23.156522 [ 20345 ] {8a7ebecf-66b0-4599-b11d-285847a4486a} TCPHandler: Code: 42. DB::Exception: Number of arguments for function MD5 doesn't match: passed 2, should be 1: In scope SELECT MD5(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:07:23.301661 [ 3110 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:07:23.687084 [ 3142 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:07:23.697121 [ 3152 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:07:23.712968 [ 3137 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:07:23.773928 [ 5904 ] {} test_0473czib.mt (37fd3cf2-879f-4934-ac8d-662471988a31): dropAllData: got exception removing parts from disk, removing successfully removed parts from memory. 2025.09.09 15:07:23.778563 [ 5904 ] {} DatabaseCatalog: Cannot drop table test_0473czib.mt (37fd3cf2-879f-4934-ac8d-662471988a31). 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af80b71 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80746 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000263a174e 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002c47c445 8. ./contrib/llvm-project/libcxx/include/vector:547: DB::MergeTreeData::clearPartsFromFilesystem(std::vector, std::allocator>> const&, bool, std::unordered_set, std::equal_to, std::allocator>*) @ 0x000000002c47a78e 9. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::dropAllData() @ 0x000000002c4862d9 10. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::dropTableFinally(DB::DatabaseCatalog::TableMarkedAsDropped const&) @ 0x00000000286c7c77 11. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: void std::__function::__policy_invoker::__call_impl, std::allocator>>)::$_0, void ()>>(std::__function::__policy_storage const*) @ 0x00000000286d9744 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000263a3ea5 13. ./contrib/llvm-project/libcxx/include/future:0: std::packaged_task::operator()() @ 0x000000001bba33ac 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7eaf0 15. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001af8a79f 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 18. asan_thread_start(void*) @ 0x000000000aa43059 19. ? @ 0x00007f35aab92ac3 20. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:07:23.847762 [ 20345 ] {7af99c43-b375-483f-9a7d-15d9034d79cb} executeQuery: Code: 42. DB::Exception: Number of arguments for function length doesn't match: passed 2, should be 1: In scope SELECT OCTET_LENGTH(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT OCTET_LENGTH(NULL, NULL);) 2025.09.09 15:07:23.852841 [ 20345 ] {7af99c43-b375-483f-9a7d-15d9034d79cb} TCPHandler: Code: 42. DB::Exception: Number of arguments for function length doesn't match: passed 2, should be 1: In scope SELECT OCTET_LENGTH(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:07:24.312386 [ 3193 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:07:24.354866 [ 20345 ] {36a56c2f-f368-4c5c-a201-047e7a43ce4b} executeQuery: Code: 42. DB::Exception: Number of arguments for function replaceRegexpAll doesn't match: passed 2, should be 3: In scope SELECT REGEXP_REPLACE(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT REGEXP_REPLACE(NULL, NULL);) 2025.09.09 15:07:24.359115 [ 20345 ] {36a56c2f-f368-4c5c-a201-047e7a43ce4b} TCPHandler: Code: 42. DB::Exception: Number of arguments for function replaceRegexpAll doesn't match: passed 2, should be 3: In scope SELECT REGEXP_REPLACE(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:07:24.431968 [ 20345 ] {1f61b2a5-22e2-4ef2-a710-5487b1da6144} executeQuery: Code: 42. DB::Exception: Number of arguments for function currentDatabase doesn't match: passed 2, should be 0: In scope SELECT SCHEMA(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT SCHEMA(NULL, NULL);) 2025.09.09 15:07:24.436642 [ 20345 ] {1f61b2a5-22e2-4ef2-a710-5487b1da6144} TCPHandler: Code: 42. DB::Exception: Number of arguments for function currentDatabase doesn't match: passed 2, should be 0: In scope SELECT SCHEMA(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:07:24.677177 [ 20345 ] {e868bd86-2a7c-44e7-ad31-7c4adbeb8c1c} executeQuery: Code: 42. DB::Exception: Number of arguments for function SHA1 doesn't match: passed 2, should be 1: In scope SELECT SHA1(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT SHA1(NULL, NULL);) 2025.09.09 15:07:24.694700 [ 3234 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:07:24.716637 [ 2752 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:07:24.719631 [ 2752 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:07:24.730138 [ 20345 ] {e868bd86-2a7c-44e7-ad31-7c4adbeb8c1c} TCPHandler: Code: 42. DB::Exception: Number of arguments for function SHA1 doesn't match: passed 2, should be 1: In scope SELECT SHA1(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:07:24.877541 [ 20345 ] {72b4c246-bc5e-4a4d-99b1-8e69bceb4e5f} executeQuery: Code: 42. DB::Exception: Number of arguments for function SHA224 doesn't match: passed 2, should be 1: In scope SELECT SHA224(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT SHA224(NULL, NULL);) 2025.09.09 15:07:24.880869 [ 20345 ] {72b4c246-bc5e-4a4d-99b1-8e69bceb4e5f} TCPHandler: Code: 42. DB::Exception: Number of arguments for function SHA224 doesn't match: passed 2, should be 1: In scope SELECT SHA224(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:07:24.975162 [ 20345 ] {572466a9-390c-43c2-a6d1-2f154c170b4b} executeQuery: Code: 42. DB::Exception: Number of arguments for function SHA256 doesn't match: passed 2, should be 1: In scope SELECT SHA256(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT SHA256(NULL, NULL);) 2025.09.09 15:07:24.983738 [ 20345 ] {572466a9-390c-43c2-a6d1-2f154c170b4b} TCPHandler: Code: 42. DB::Exception: Number of arguments for function SHA256 doesn't match: passed 2, should be 1: In scope SELECT SHA256(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:07:25.154723 [ 20345 ] {b6f91699-616d-493d-aff4-ad6e8372b25b} executeQuery: Code: 42. DB::Exception: Number of arguments for function SHA384 doesn't match: passed 2, should be 1: In scope SELECT SHA384(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT SHA384(NULL, NULL);) 2025.09.09 15:07:25.166286 [ 20345 ] {b6f91699-616d-493d-aff4-ad6e8372b25b} TCPHandler: Code: 42. DB::Exception: Number of arguments for function SHA384 doesn't match: passed 2, should be 1: In scope SELECT SHA384(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:07:25.311379 [ 20345 ] {cdb4ece1-978d-47e7-9632-286bc6cdb965} executeQuery: Code: 42. DB::Exception: Number of arguments for function SHA512 doesn't match: passed 2, should be 1: In scope SELECT SHA512(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT SHA512(NULL, NULL);) 2025.09.09 15:07:25.314949 [ 2766 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:07:25.315217 [ 20345 ] {cdb4ece1-978d-47e7-9632-286bc6cdb965} TCPHandler: Code: 42. DB::Exception: Number of arguments for function SHA512 doesn't match: passed 2, should be 1: In scope SELECT SHA512(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:07:25.431754 [ 20345 ] {3ffc8220-b544-4e4d-af4f-30e28f895cb0} executeQuery: Code: 42. DB::Exception: Number of arguments for function SHA512_256 doesn't match: passed 2, should be 1: In scope SELECT SHA512_256(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT SHA512_256(NULL, NULL);) 2025.09.09 15:07:25.436876 [ 20345 ] {3ffc8220-b544-4e4d-af4f-30e28f895cb0} TCPHandler: Code: 42. DB::Exception: Number of arguments for function SHA512_256 doesn't match: passed 2, should be 1: In scope SELECT SHA512_256(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:07:25.455317 [ 3612 ] {2fa2729b-a486-4709-b104-0c382f66fd36} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=4, jobs=4). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:41188) (comment: 02789_filesystem_cache_alignment.sh) (in query: SELECT count() FROM ( SELECT cache_path, file_size, tupleElement(file_segment_range, 2) - tupleElement(file_segment_range, 1) + 1 as file_segment_size, formatReadableSize(file_size) as formatted_file_size, formatReadableSize(file_segment_size) as formatted_file_segment_size, tupleElement(file_segment_range, 2) as end_offset FROM ( SELECT arrayJoin(cache_paths) AS cache_path, local_path, remote_path, size as file_size FROM system.remote_data_paths WHERE endsWith(local_path, '.bin') ) AS data_paths INNER JOIN system.filesystem_cache_log AS cache_log ON data_paths.remote_path = cache_log.source_file_path WHERE query_id = '20490' ) WHERE file_segment_size < file_size AND end_offset + 1 != file_size AND formatted_file_segment_size in ('20.00 MiB', '40.00 MiB') ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af819ed 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80746 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d34b5ca 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000002d3486e4 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000002d34827b 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002d36bcf7 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 12. asan_thread_start(void*) @ 0x000000000aa43059 13. ? @ 0x00007f35aab92ac3 14. ? @ 0x00007f35aac24850 2025.09.09 15:07:25.516138 [ 3612 ] {2fa2729b-a486-4709-b104-0c382f66fd36} TCPHandler: 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af819ed 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80746 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d34b5ca 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000002d3486e4 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000002d34827b 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002d36bcf7 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 12. asan_thread_start(void*) @ 0x000000000aa43059 13. ? @ 0x00007f35aab92ac3 14. ? @ 0x00007f35aac24850 2025.09.09 15:07:25.697533 [ 3065 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:07:25.719141 [ 3058 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:07:25.722128 [ 2754 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:07:26.032526 [ 20881 ] {34e52f7c-8e96-4117-8abd-e236b2b2690a} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:41198) (comment: 01542_dictionary_load_exception_race.sh) (in query: DROP DATABASE IF EXISTS database_for_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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aac868e 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x00000000286b57c7 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x00000000291f5630 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:361: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000291edc97 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x00000000291ebf11 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x00000000291eb7ed 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b382fc 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 15:07:26.047134 [ 20345 ] {1bd8f794-6af6-4ed8-8b27-e7eb29e67d8e} executeQuery: Code: 42. DB::Exception: Number of arguments for function substringIndex doesn't match: passed 2, should be 3: In scope SELECT SUBSTRING_INDEX(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT SUBSTRING_INDEX(NULL, NULL);) 2025.09.09 15:07:26.047239 [ 20881 ] {34e52f7c-8e96-4117-8abd-e236b2b2690a} TCPHandler: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aac868e 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x00000000286b57c7 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x00000000291f5630 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:361: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000291edc97 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x00000000291ebf11 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x00000000291eb7ed 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b382fc 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 15:07:26.054003 [ 20345 ] {1bd8f794-6af6-4ed8-8b27-e7eb29e67d8e} TCPHandler: Code: 42. DB::Exception: Number of arguments for function substringIndex doesn't match: passed 2, should be 3: In scope SELECT SUBSTRING_INDEX(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:07:26.222811 [ 3612 ] {b50b3c70-8d56-477c-9274-86a248528620} 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=5, jobs=0). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af819ed 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af82f33 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000287ad950 7. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:35: DB::chooseJoinAlgorithm(std::shared_ptr&, std::shared_ptr const&, DB::Block const&, DB::Block const&, std::shared_ptr const&) @ 0x00000000294a6614 8. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1490: DB::(anonymous namespace)::buildQueryPlanForJoinNode(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000002947642f 9. ./build_docker/./src/Planner/PlannerJoinTree.cpp:0: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000002945f174 10. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x000000002942c986 11. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x00000000294261fb 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) @ 0x0000000029464fdb 13. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1795: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000002945d99d 14. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x000000002942c986 15. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x00000000294261fb 16. ./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) @ 0x0000000029464fdb 17. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1795: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000002945d99d 18. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x000000002942c986 19. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x00000000294261fb 20. ./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) @ 0x0000000029464fdb 21. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1795: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000002945d99d 22. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x000000002942c986 23. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x00000000294261fb 24. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000029421552 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1182: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3737e 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 27. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 28. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:07:26.318907 [ 3612 ] {b50b3c70-8d56-477c-9274-86a248528620} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=5, jobs=0). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:41196) (comment: 02789_filesystem_cache_alignment.sh) (in query: SELECT count() FROM ( SELECT * FROM (SELECT * FROM ( SELECT cache_path, file_size, tupleElement(file_segment_range, 2) - tupleElement(file_segment_range, 1) + 1 as file_segment_size, formatReadableSize(file_size) as formatted_file_size, formatReadableSize(file_segment_size) as formatted_file_segment_size, tupleElement(file_segment_range, 2) as end_offset FROM ( SELECT arrayJoin(cache_paths) AS cache_path, local_path, remote_path, size as file_size FROM system.remote_data_paths WHERE endsWith(local_path, '.bin') ) AS data_paths INNER JOIN system.filesystem_cache_log AS cache_log ON data_paths.remote_path = cache_log.source_file_path WHERE query_id = '20490' )) AS cache_log INNER JOIN system.filesystem_cache AS cache ON cache_log.cache_path = cache.cache_path ) WHERE file_segment_range_begin - file_segment_range_end + 1 < file_size AND file_segment_range_end + 1 != file_size AND downloaded_size < 20 * 1024 * 1024;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af819ed 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af82f33 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000287ad950 7. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:35: DB::chooseJoinAlgorithm(std::shared_ptr&, std::shared_ptr const&, DB::Block const&, DB::Block const&, std::shared_ptr const&) @ 0x00000000294a6614 8. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1490: DB::(anonymous namespace)::buildQueryPlanForJoinNode(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000002947642f 9. ./build_docker/./src/Planner/PlannerJoinTree.cpp:0: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000002945f174 10. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x000000002942c986 11. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x00000000294261fb 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) @ 0x0000000029464fdb 13. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1795: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000002945d99d 14. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x000000002942c986 15. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x00000000294261fb 16. ./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) @ 0x0000000029464fdb 17. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1795: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000002945d99d 18. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x000000002942c986 19. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x00000000294261fb 20. ./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) @ 0x0000000029464fdb 21. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1795: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000002945d99d 22. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x000000002942c986 23. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x00000000294261fb 24. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000029421552 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1182: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3737e 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 27. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 28. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 2025.09.09 15:07:26.337061 [ 3612 ] {b50b3c70-8d56-477c-9274-86a248528620} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=5, jobs=0). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af819ed 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af82f33 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000287ad950 7. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:35: DB::chooseJoinAlgorithm(std::shared_ptr&, std::shared_ptr const&, DB::Block const&, DB::Block const&, std::shared_ptr const&) @ 0x00000000294a6614 8. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1490: DB::(anonymous namespace)::buildQueryPlanForJoinNode(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000002947642f 9. ./build_docker/./src/Planner/PlannerJoinTree.cpp:0: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000002945f174 10. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x000000002942c986 11. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x00000000294261fb 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) @ 0x0000000029464fdb 13. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1795: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000002945d99d 14. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x000000002942c986 15. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x00000000294261fb 16. ./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) @ 0x0000000029464fdb 17. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1795: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000002945d99d 18. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x000000002942c986 19. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x00000000294261fb 20. ./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) @ 0x0000000029464fdb 21. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1795: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000002945d99d 22. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x000000002942c986 23. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x00000000294261fb 24. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000029421552 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1182: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3737e 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 27. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 28. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 2025.09.09 15:07:26.337559 [ 2872 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:07:26.633366 [ 20345 ] {1dac3795-78b7-44ba-888f-5afe6fead267} executeQuery: Code: 42. DB::Exception: Number of arguments for function base64Encode doesn't match: passed 2, should be 1: In scope SELECT TO_BASE64(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT TO_BASE64(NULL, NULL);) 2025.09.09 15:07:26.645295 [ 20345 ] {1dac3795-78b7-44ba-888f-5afe6fead267} TCPHandler: Code: 42. DB::Exception: Number of arguments for function base64Encode doesn't match: passed 2, should be 1: In scope SELECT TO_BASE64(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:07:26.714621 [ 2846 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:07:26.721763 [ 2857 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:07:26.732739 [ 2860 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:07:26.876693 [ 20881 ] {6ae80bac-d03b-4da0-9a0d-38d8fab0ff0d} executeQuery: Code: 82. DB::Exception: Database database_for_dict already exists. (DATABASE_ALREADY_EXISTS) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:41206) (comment: 01542_dictionary_load_exception_race.sh) (in query: CREATE DATABASE database_for_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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x000000000aafc574 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:146: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002918fd00 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000291c33d8 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b382fc 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 9. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 13. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 14. asan_thread_start(void*) @ 0x000000000aa43059 15. ? @ 0x00007f35aab92ac3 16. ? @ 0x00007f35aac24850 2025.09.09 15:07:26.879474 [ 20881 ] {6ae80bac-d03b-4da0-9a0d-38d8fab0ff0d} TCPHandler: Code: 82. DB::Exception: Database database_for_dict already exists. (DATABASE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x000000000aafc574 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:146: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002918fd00 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000291c33d8 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b382fc 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 9. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 13. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 14. asan_thread_start(void*) @ 0x000000000aa43059 15. ? @ 0x00007f35aab92ac3 16. ? @ 0x00007f35aac24850 2025.09.09 15:07:27.336621 [ 20345 ] {697ffa36-3909-4c7e-8b09-3d731b0f7a1b} executeQuery: Code: 42. DB::Exception: Number of arguments for function URLHierarchy doesn't match: passed 2, should be 1: In scope SELECT URLHierarchy(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT URLHierarchy(NULL, NULL);) 2025.09.09 15:07:27.341755 [ 20345 ] {697ffa36-3909-4c7e-8b09-3d731b0f7a1b} TCPHandler: Code: 42. DB::Exception: Number of arguments for function URLHierarchy doesn't match: passed 2, should be 1: In scope SELECT URLHierarchy(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:07:27.349712 [ 2908 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:07:27.442136 [ 20345 ] {be7e0b65-fb4e-4042-a5fb-cf59e83a7e97} executeQuery: Code: 42. DB::Exception: Number of arguments for function URLPathHierarchy doesn't match: passed 2, should be 1: In scope SELECT URLPathHierarchy(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT URLPathHierarchy(NULL, NULL);) 2025.09.09 15:07:27.445377 [ 20345 ] {be7e0b65-fb4e-4042-a5fb-cf59e83a7e97} TCPHandler: Code: 42. DB::Exception: Number of arguments for function URLPathHierarchy doesn't match: passed 2, should be 1: In scope SELECT URLPathHierarchy(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:07:27.610314 [ 20345 ] {a1bb7dd3-f7d5-4682-b9e3-11b214b63683} executeQuery: Code: 42. DB::Exception: Number of arguments for function UTCTimestamp doesn't match: passed 2, should be 0: In scope SELECT UTCTimestamp(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT UTCTimestamp(NULL, NULL);) 2025.09.09 15:07:27.614823 [ 20345 ] {a1bb7dd3-f7d5-4682-b9e3-11b214b63683} TCPHandler: Code: 42. DB::Exception: Number of arguments for function UTCTimestamp doesn't match: passed 2, should be 0: In scope SELECT UTCTimestamp(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:07:27.615962 [ 20881 ] {63ff19df-ba4f-40e1-8b8a-124f0199c8b7} executeQuery: Code: 630. DB::Exception: Cannot drop or rename database_for_dict.table_for_dict (cabf9a66-80e2-4148-8335-3c53187f5a8a), because some tables depend on it: ordinary_db.dict1. (HAVE_DEPENDENT_OBJECTS) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:41210) (comment: 01542_dictionary_load_exception_race.sh) (in query: DROP TABLE IF EXISTS database_for_dict.table_for_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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception, std::__wrap_iter, char>>(int, FormatStringHelperImpl::type, std::type_identity, std::__wrap_iter, char>>::type>, DB::StorageID const&, fmt::v9::join_view, std::__wrap_iter, char>&&) @ 0x00000000286dbc7a 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:1523: DB::DatabaseCatalog::checkTableCanBeRemovedOrRenamedUnlocked(DB::StorageID const&, bool, bool, bool) const @ 0x00000000286cc315 5. ./contrib/llvm-project/libcxx/include/__mutex_base:100: DB::DatabaseCatalog::checkTableCanBeRemovedOrRenamed(DB::StorageID const&, bool, bool, bool) const @ 0x00000000286cc97f 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x00000000291f0b89 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x00000000291ed665 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x00000000291ebd68 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x00000000291eb7ed 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b382fc 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 13. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 18. asan_thread_start(void*) @ 0x000000000aa43059 19. ? @ 0x00007f35aab92ac3 20. ? @ 0x00007f35aac24850 2025.09.09 15:07:27.622739 [ 20881 ] {63ff19df-ba4f-40e1-8b8a-124f0199c8b7} TCPHandler: Code: 630. DB::Exception: Cannot drop or rename database_for_dict.table_for_dict (cabf9a66-80e2-4148-8335-3c53187f5a8a), because some tables depend on it: ordinary_db.dict1. (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception, std::__wrap_iter, char>>(int, FormatStringHelperImpl::type, std::type_identity, std::__wrap_iter, char>>::type>, DB::StorageID const&, fmt::v9::join_view, std::__wrap_iter, char>&&) @ 0x00000000286dbc7a 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:1523: DB::DatabaseCatalog::checkTableCanBeRemovedOrRenamedUnlocked(DB::StorageID const&, bool, bool, bool) const @ 0x00000000286cc315 5. ./contrib/llvm-project/libcxx/include/__mutex_base:100: DB::DatabaseCatalog::checkTableCanBeRemovedOrRenamed(DB::StorageID const&, bool, bool, bool) const @ 0x00000000286cc97f 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x00000000291f0b89 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x00000000291ed665 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x00000000291ebd68 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x00000000291eb7ed 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b382fc 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 13. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 18. asan_thread_start(void*) @ 0x000000000aa43059 19. ? @ 0x00007f35aab92ac3 20. ? @ 0x00007f35aac24850 2025.09.09 15:07:27.690429 [ 20345 ] {d8c8a423-4933-4e31-8d3d-45996ef42b83} executeQuery: Code: 42. DB::Exception: Number of arguments for function UTCTimestamp doesn't match: passed 2, should be 0: In scope SELECT UTC_timestamp(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT UTC_timestamp(NULL, NULL);) 2025.09.09 15:07:27.702786 [ 20345 ] {d8c8a423-4933-4e31-8d3d-45996ef42b83} TCPHandler: Code: 42. DB::Exception: Number of arguments for function UTCTimestamp doesn't match: passed 2, should be 0: In scope SELECT UTC_timestamp(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:07:27.723843 [ 2954 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:07:27.724484 [ 2959 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:07:27.734804 [ 2970 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:07:28.328449 [ 20881 ] {db185376-af6d-434d-8efd-3e3ab81041bb} executeQuery: Code: 57. DB::Exception: Table database_for_dict.table_for_dict already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:46036) (comment: 01542_dictionary_load_exception_race.sh) (in query: CREATE TABLE database_for_dict.table_for_dict (`key_column` UInt64, `second_column` UInt64, `third_column` String) ENGINE = MergeTree ORDER BY key_column SETTINGS index_granularity = 60578, min_bytes_for_wide_part = 592817471, ratio_of_defaults_for_sparse_serialization = 0.3581370711326599, replace_long_file_name_to_hash = false, max_file_name_length = 60, min_bytes_for_full_part_storage = 510714276, compact_parts_max_bytes_to_buffer = 480424706, compact_parts_max_granules_to_buffer = 127, compact_parts_merge_max_bytes_to_prefetch_part = 31072451, merge_max_block_size = 24278, old_parts_lifetime = 480., prefer_fetch_merged_part_size_threshold = 10737418240, vertical_merge_algorithm_min_rows_to_activate = 1000000, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 10737418240, index_granularity_bytes = 3546291, concurrent_part_removal_threshold = 14, allow_vertical_merges_from_compact_to_wide_parts = true, cache_populated_by_fetch = true, marks_compress_block_size = 74214, primary_key_compress_block_size = 17858), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa91e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1558: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291bc5ff 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291ac835 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000291c3415 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b382fc 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 15. asan_thread_start(void*) @ 0x000000000aa43059 16. ? @ 0x00007f35aab92ac3 17. ? @ 0x00007f35aac24850 2025.09.09 15:07:28.331439 [ 20881 ] {db185376-af6d-434d-8efd-3e3ab81041bb} TCPHandler: Code: 57. DB::Exception: Table database_for_dict.table_for_dict already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa91e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1558: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291bc5ff 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291ac835 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000291c3415 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b382fc 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 15. asan_thread_start(void*) @ 0x000000000aa43059 16. ? @ 0x00007f35aab92ac3 17. ? @ 0x00007f35aac24850 2025.09.09 15:07:28.352305 [ 3026 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:07:28.725824 [ 3042 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:07:28.726408 [ 3027 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:07:28.739015 [ 3038 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:07:28.783122 [ 3040 ] {} 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af819ed 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80746 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000263a174e 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000286c6b9c 8. ./contrib/llvm-project/libcxx/include/vector:590: DB::DatabaseCatalog::dropTableDataTask() @ 0x00000000286c7466 9. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 11. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 14. asan_thread_start(void*) @ 0x000000000aa43059 15. ? @ 0x00007f35aab92ac3 16. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:07:28.798489 [ 5903 ] {} test_0473czib.mt (37fd3cf2-879f-4934-ac8d-662471988a31): dropAllData: got exception removing parts from disk, removing successfully removed parts from memory. 2025.09.09 15:07:28.803537 [ 5903 ] {} DatabaseCatalog: Cannot drop table test_0473czib.mt (37fd3cf2-879f-4934-ac8d-662471988a31). 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af819ed 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80746 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000263a174e 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002c47c445 8. ./contrib/llvm-project/libcxx/include/vector:547: DB::MergeTreeData::clearPartsFromFilesystem(std::vector, std::allocator>> const&, bool, std::unordered_set, std::equal_to, std::allocator>*) @ 0x000000002c47a78e 9. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::dropAllData() @ 0x000000002c4862d9 10. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::dropTableFinally(DB::DatabaseCatalog::TableMarkedAsDropped const&) @ 0x00000000286c7c77 11. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: void std::__function::__policy_invoker::__call_impl, std::allocator>>)::$_0, void ()>>(std::__function::__policy_storage const*) @ 0x00000000286d9744 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000263a3ea5 13. ./contrib/llvm-project/libcxx/include/future:0: std::packaged_task::operator()() @ 0x000000001bba33ac 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7eaf0 15. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001af8a79f 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 18. asan_thread_start(void*) @ 0x000000000aa43059 19. ? @ 0x00007f35aab92ac3 20. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:07:29.248419 [ 20345 ] {6c9ff99e-7c1f-4b93-8937-808d8ad11b99} executeQuery: Code: 43. DB::Exception: Second argument to _CAST must be a constant string describing type. Instead there is a column with the following structure: Const(size = 1, Nullable(size = 1, Nothing(size = 1), UInt8(size = 1))): In scope SELECT _CAST(NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT _CAST(NULL, NULL);) 2025.09.09 15:07:29.257865 [ 20345 ] {6c9ff99e-7c1f-4b93-8937-808d8ad11b99} TCPHandler: Code: 43. DB::Exception: Second argument to _CAST must be a constant string describing type. Instead there is a column with the following structure: Const(size = 1, Nullable(size = 1, Nothing(size = 1), UInt8(size = 1))): In scope SELECT _CAST(NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.09.09 15:07:29.355727 [ 3093 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:07:29.393436 [ 20345 ] {517ea326-a4d5-418d-8a93-cc266f2e9e7c} executeQuery: Code: 36. DB::Exception: Function __actionName is internal nad should not be used directly: In scope SELECT __actionName(NULL, NULL). (BAD_ARGUMENTS) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT __actionName(NULL, NULL);) 2025.09.09 15:07:29.401135 [ 20345 ] {517ea326-a4d5-418d-8a93-cc266f2e9e7c} TCPHandler: Code: 36. DB::Exception: Function __actionName is internal nad should not be used directly: In scope SELECT __actionName(NULL, NULL). (BAD_ARGUMENTS) 2025.09.09 15:07:29.727864 [ 3099 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:07:29.728147 [ 3110 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:07:29.740850 [ 3117 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:07:29.857927 [ 20345 ] {f1cffa11-038f-487d-9fd5-19a5d4b47e84} executeQuery: Code: 42. DB::Exception: Number of arguments for function __bitSwapLastTwo doesn't match: passed 2, should be 1: In scope SELECT __bitSwapLastTwo(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT __bitSwapLastTwo(NULL, NULL);) 2025.09.09 15:07:29.864673 [ 20345 ] {f1cffa11-038f-487d-9fd5-19a5d4b47e84} TCPHandler: Code: 42. DB::Exception: Number of arguments for function __bitSwapLastTwo doesn't match: passed 2, should be 1: In scope SELECT __bitSwapLastTwo(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:07:30.010475 [ 20881 ] {eb9427e2-90d9-4972-8497-157b3233f9bc} executeQuery: Code: 62. DB::Exception: Cannot TRUNCATE dictionary. (SYNTAX_ERROR) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:46050) (comment: 01542_dictionary_load_exception_race.sh) (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aac868e 4. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:262: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x00000000291f1adc 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>>>&) @ 0x00000000291f510c 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:361: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000291edc97 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x00000000291ebf11 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x00000000291eb7ed 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b382fc 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 15:07:30.010652 [ 20345 ] {2565badb-112a-4159-bd72-79d1332d1f8a} executeQuery: Code: 42. DB::Exception: Number of arguments for function __bitWrapperFunc doesn't match: passed 2, should be 1: In scope SELECT __bitWrapperFunc(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT __bitWrapperFunc(NULL, NULL);) 2025.09.09 15:07:30.017780 [ 20881 ] {eb9427e2-90d9-4972-8497-157b3233f9bc} 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aac868e 4. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:262: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x00000000291f1adc 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>>>&) @ 0x00000000291f510c 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:361: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000291edc97 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x00000000291ebf11 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x00000000291eb7ed 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b382fc 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 15:07:30.018027 [ 20345 ] {2565badb-112a-4159-bd72-79d1332d1f8a} TCPHandler: Code: 42. DB::Exception: Number of arguments for function __bitWrapperFunc doesn't match: passed 2, should be 1: In scope SELECT __bitWrapperFunc(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:07:30.095775 [ 20345 ] {91be42c6-2ecd-409c-97f8-f65f222f9da6} executeQuery: Code: 42. DB::Exception: Number of arguments for function __getScalar doesn't match: passed 2, should be 1: In scope SELECT __getScalar(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT __getScalar(NULL, NULL);) 2025.09.09 15:07:30.171969 [ 20345 ] {91be42c6-2ecd-409c-97f8-f65f222f9da6} TCPHandler: Code: 42. DB::Exception: Number of arguments for function __getScalar doesn't match: passed 2, should be 1: In scope SELECT __getScalar(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:07:30.313518 [ 20345 ] {13ce4bdd-484b-464d-91f3-282345cbb298} executeQuery: Code: 42. DB::Exception: Number of arguments for function __scalarSubqueryResult doesn't match: passed 2, should be 1: In scope SELECT __scalarSubqueryResult(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT __scalarSubqueryResult(NULL, NULL);) 2025.09.09 15:07:30.319413 [ 20345 ] {13ce4bdd-484b-464d-91f3-282345cbb298} TCPHandler: Code: 42. DB::Exception: Number of arguments for function __scalarSubqueryResult doesn't match: passed 2, should be 1: In scope SELECT __scalarSubqueryResult(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:07:30.356988 [ 20345 ] {c9ea1c88-5979-4cef-87ba-ac861cfb0492} executeQuery: Code: 42. DB::Exception: Number of arguments for function abs doesn't match: passed 2, should be 1: In scope SELECT abs(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT abs(NULL, NULL);) 2025.09.09 15:07:30.357744 [ 3161 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:07:30.359785 [ 20345 ] {c9ea1c88-5979-4cef-87ba-ac861cfb0492} TCPHandler: Code: 42. DB::Exception: Number of arguments for function abs doesn't match: passed 2, should be 1: In scope SELECT abs(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:07:30.414424 [ 20345 ] {b469abdc-a6f1-42bd-8400-7f20309a4400} executeQuery: Code: 43. DB::Exception: Second argument to accurateCast must be a constant string describing type. Instead there is a column with the following structure: Const(size = 1, Nullable(size = 1, Nothing(size = 1), UInt8(size = 1))): In scope SELECT accurateCast(NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT accurateCast(NULL, NULL);) 2025.09.09 15:07:30.417590 [ 20345 ] {b469abdc-a6f1-42bd-8400-7f20309a4400} TCPHandler: Code: 43. DB::Exception: Second argument to accurateCast must be a constant string describing type. Instead there is a column with the following structure: Const(size = 1, Nullable(size = 1, Nothing(size = 1), UInt8(size = 1))): In scope SELECT accurateCast(NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.09.09 15:07:30.491917 [ 20345 ] {5b95d1e2-4180-4547-bf02-aec543e5aa7c} executeQuery: Code: 43. DB::Exception: Second argument to accurateCastOrDefault must be a constant string describing type. Actual Nullable(Nothing): In scope SELECT accurateCastOrDefault(NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT accurateCastOrDefault(NULL, NULL);) 2025.09.09 15:07:30.499222 [ 20345 ] {5b95d1e2-4180-4547-bf02-aec543e5aa7c} TCPHandler: Code: 43. DB::Exception: Second argument to accurateCastOrDefault must be a constant string describing type. Actual Nullable(Nothing): In scope SELECT accurateCastOrDefault(NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.09.09 15:07:30.567662 [ 20345 ] {61cc1a8c-0b1d-4364-ade7-46bfc67aa2ad} executeQuery: Code: 43. DB::Exception: Second argument to accurateCastOrNull must be a constant string describing type. Instead there is a column with the following structure: Const(size = 1, Nullable(size = 1, Nothing(size = 1), UInt8(size = 1))): In scope SELECT accurateCastOrNull(NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT accurateCastOrNull(NULL, NULL);) 2025.09.09 15:07:30.574756 [ 20345 ] {61cc1a8c-0b1d-4364-ade7-46bfc67aa2ad} TCPHandler: Code: 43. DB::Exception: Second argument to accurateCastOrNull must be a constant string describing type. Instead there is a column with the following structure: Const(size = 1, Nullable(size = 1, Nothing(size = 1), UInt8(size = 1))): In scope SELECT accurateCastOrNull(NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.09.09 15:07:30.612672 [ 20345 ] {afc0bafb-51e5-431a-9142-759473fcd9f2} executeQuery: Code: 42. DB::Exception: Number of arguments for function acos doesn't match: passed 2, should be 1: In scope SELECT acos(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT acos(NULL, NULL);) 2025.09.09 15:07:30.614902 [ 20345 ] {afc0bafb-51e5-431a-9142-759473fcd9f2} TCPHandler: Code: 42. DB::Exception: Number of arguments for function acos doesn't match: passed 2, should be 1: In scope SELECT acos(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:07:30.682075 [ 20881 ] {dc96ffc4-3ef3-4d94-9d46-18d7c35af38b} executeQuery: Code: 82. DB::Exception: Database ordinary_db already exists. (DATABASE_ALREADY_EXISTS) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:46060) (comment: 01542_dictionary_load_exception_race.sh) (in query: CREATE DATABASE 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x000000000aafc574 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:146: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002918fd00 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000291c33d8 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b382fc 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 9. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 13. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 14. asan_thread_start(void*) @ 0x000000000aa43059 15. ? @ 0x00007f35aab92ac3 16. ? @ 0x00007f35aac24850 2025.09.09 15:07:30.685352 [ 20345 ] {cf66e79b-1c7c-4389-bf68-2e97e17274bb} executeQuery: Code: 42. DB::Exception: Number of arguments for function acosh doesn't match: passed 2, should be 1: In scope SELECT acosh(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT acosh(NULL, NULL);) 2025.09.09 15:07:30.686615 [ 20881 ] {dc96ffc4-3ef3-4d94-9d46-18d7c35af38b} TCPHandler: Code: 82. DB::Exception: Database ordinary_db already exists. (DATABASE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x000000000aafc574 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:146: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002918fd00 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000291c33d8 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b382fc 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 9. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 13. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 14. asan_thread_start(void*) @ 0x000000000aa43059 15. ? @ 0x00007f35aab92ac3 16. ? @ 0x00007f35aac24850 2025.09.09 15:07:30.700445 [ 20345 ] {cf66e79b-1c7c-4389-bf68-2e97e17274bb} TCPHandler: Code: 42. DB::Exception: Number of arguments for function acosh doesn't match: passed 2, should be 1: In scope SELECT acosh(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:07:30.730021 [ 3231 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:07:30.730328 [ 3154 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:07:30.742927 [ 2737 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:07:30.906759 [ 20345 ] {0114bc9b-0952-47fb-80e4-299b235ebbe3} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=790, jobs=752). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT addDays(NULL, NULL);) 2025.09.09 15:07:30.911916 [ 20345 ] {0114bc9b-0952-47fb-80e4-299b235ebbe3} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=790, jobs=752). (CANNOT_SCHEDULE_TASK) 2025.09.09 15:07:31.360416 [ 2778 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:07:31.440599 [ 20881 ] {501ea6a8-e8b2-42db-90a7-bc7cef28a1b5} executeQuery: Code: 387. DB::Exception: Dictionary ordinary_db.dict1 already exists. (DICTIONARY_ALREADY_EXISTS) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:46072) (comment: 01542_dictionary_load_exception_race.sh) (in query: CREATE DICTIONARY ordinary_db.dict1 (`key_column` UInt64 DEFAULT 0, `second_column` UInt64 DEFAULT 1, `third_column` String DEFAULT 'qqq') PRIMARY KEY key_column SOURCE(CLICKHOUSE(HOST 'localhost' PORT tcpPort() USER 'default' TABLE 'table_for_dict' PASSWORD '[HIDDEN]' DB 'database_for_dict')) LIFETIME(MIN 1 MAX 10) LAYOUT(FLAT()) SETTINGS(max_result_bytes = 1)), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa91e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1555: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291bc592 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291ac835 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000291c3415 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b382fc 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 15. asan_thread_start(void*) @ 0x000000000aa43059 16. ? @ 0x00007f35aab92ac3 17. ? @ 0x00007f35aac24850 2025.09.09 15:07:31.457372 [ 20881 ] {501ea6a8-e8b2-42db-90a7-bc7cef28a1b5} TCPHandler: Code: 387. DB::Exception: Dictionary ordinary_db.dict1 already exists. (DICTIONARY_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa91e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1555: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291bc592 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291ac835 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000291c3415 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b382fc 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 15. asan_thread_start(void*) @ 0x000000000aa43059 16. ? @ 0x00007f35aab92ac3 17. ? @ 0x00007f35aac24850 2025.09.09 15:07:31.691212 [ 3612 ] {715c0c29-3bf7-49ff-8822-d672b2efae37} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=12, jobs=12). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:41200) (comment: 02789_filesystem_cache_alignment.sh) (in query: SELECT count() FROM ( SELECT * FROM (SELECT * FROM ( SELECT cache_path, file_size, tupleElement(file_segment_range, 2) - tupleElement(file_segment_range, 1) + 1 as file_segment_size, formatReadableSize(file_size) as formatted_file_size, formatReadableSize(file_segment_size) as formatted_file_segment_size, tupleElement(file_segment_range, 2) as end_offset FROM ( SELECT arrayJoin(cache_paths) AS cache_path, local_path, remote_path, size as file_size FROM system.remote_data_paths WHERE endsWith(local_path, '.bin') ) AS data_paths INNER JOIN system.filesystem_cache_log AS cache_log ON data_paths.remote_path = cache_log.source_file_path WHERE query_id = '20490' )) AS cache_log INNER JOIN system.filesystem_cache AS cache ON cache_log.cache_path = cache.cache_path ) WHERE file_segment_range_begin - file_segment_range_end + 1 < file_size AND file_segment_range_end + 1 != file_size AND formatReadableSize(downloaded_size) not in ('20.00 MiB', '40.00 MiB');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af819ed 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80746 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d34b5ca 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:306: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349fbb 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:381: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000002d34bd35 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7eaf0 10. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001af8a79f 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 13. asan_thread_start(void*) @ 0x000000000aa43059 14. ? @ 0x00007f35aab92ac3 15. ? @ 0x00007f35aac24850 2025.09.09 15:07:31.705806 [ 3612 ] {715c0c29-3bf7-49ff-8822-d672b2efae37} virtual DB::ConcurrentHashJoin::~ConcurrentHashJoin(): 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af80b71 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af82f33 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000287ae4d3 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:216: DB::JoiningTransform::~JoiningTransform() @ 0x000000002d9d146b 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:216: std::vector, std::allocator>>::__destroy_vector::operator()[abi:v15007]() @ 0x00000000260eaf4e 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:313: std::__shared_ptr_emplace, std::allocator>>, std::allocator, std::allocator>>>>::__on_zero_shared() @ 0x000000002781a4f7 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:216: DB::QueryPipeline::~QueryPipeline() @ 0x00000000278210b3 11. ./build_docker/./src/QueryPipeline/QueryPipeline.cpp:698: DB::QueryPipeline::reset() @ 0x000000002782d48a 12. ./build_docker/./src/Server/TCPHandler.cpp:680: DB::TCPHandler::runImpl() @ 0x000000002d178c28 13. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 18. asan_thread_start(void*) @ 0x000000000aa43059 19. ? @ 0x00007f35aab92ac3 20. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:07:31.731929 [ 2811 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:07:31.732171 [ 2816 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:07:31.746580 [ 2747 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:07:31.814084 [ 3612 ] {715c0c29-3bf7-49ff-8822-d672b2efae37} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=12, jobs=12). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af819ed 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80746 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d34b5ca 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:306: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349fbb 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:381: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000002d34bd35 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7eaf0 10. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001af8a79f 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 13. asan_thread_start(void*) @ 0x000000000aa43059 14. ? @ 0x00007f35aab92ac3 15. ? @ 0x00007f35aac24850 2025.09.09 15:07:32.268858 [ 3612 ] {e90fb834-d970-4ed3-af2e-6e4b31bd9bbf} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:46076) (comment: 01542_dictionary_load_exception_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:32.269208 [ 20882 ] {905d2ad0-3737-4abb-9920-80e7f2799cc7} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:46098) (comment: 01542_dictionary_load_exception_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:32.284455 [ 20882 ] {905d2ad0-3737-4abb-9920-80e7f2799cc7} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:32.284976 [ 3612 ] {e90fb834-d970-4ed3-af2e-6e4b31bd9bbf} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:32.285359 [ 20338 ] {16e3f909-7528-4d80-88ca-e276014a3c0d} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:46112) (comment: 01542_dictionary_load_exception_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:32.295211 [ 20343 ] {61715bc7-2778-41de-8c5a-ca77deaebd6d} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:46128) (comment: 01542_dictionary_load_exception_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:32.310526 [ 20343 ] {61715bc7-2778-41de-8c5a-ca77deaebd6d} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:32.319661 [ 20338 ] {16e3f909-7528-4d80-88ca-e276014a3c0d} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:32.370649 [ 20881 ] {1901972b-8097-4e0b-83ca-4518e84c0c7f} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:46082) (comment: 01542_dictionary_load_exception_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:32.371059 [ 2860 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:07:32.373282 [ 20881 ] {1901972b-8097-4e0b-83ca-4518e84c0c7f} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:32.384424 [ 20350 ] {1e7975f7-e864-4504-aed7-950a45e5d643} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:46134) (comment: 01542_dictionary_load_exception_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:32.386520 [ 20350 ] {1e7975f7-e864-4504-aed7-950a45e5d643} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:32.430743 [ 20353 ] {03ad111c-cfe0-4ef5-9400-360b0fdff72b} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:46154) (comment: 01542_dictionary_load_exception_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:32.441713 [ 20353 ] {03ad111c-cfe0-4ef5-9400-360b0fdff72b} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:32.510378 [ 2687 ] {e582f677-60a5-49b0-87bb-72772343a9de} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:46176) (comment: 01542_dictionary_load_exception_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:32.511783 [ 20379 ] {a88cbf8a-3133-4a17-9ff4-fc011a0f63f7} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:46164) (comment: 01542_dictionary_load_exception_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:32.513199 [ 2687 ] {e582f677-60a5-49b0-87bb-72772343a9de} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:32.517452 [ 20379 ] {a88cbf8a-3133-4a17-9ff4-fc011a0f63f7} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:32.520058 [ 20355 ] {a977c983-929a-48ed-b8f2-e9f03a759994} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:46162) (comment: 01542_dictionary_load_exception_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:32.530983 [ 20355 ] {a977c983-929a-48ed-b8f2-e9f03a759994} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:32.581101 [ 20380 ] {bbcf4b32-df00-4dd0-90a4-3defa63131f6} DB::ConcurrentHashJoin::ConcurrentHashJoin(ContextPtr, std::shared_ptr, size_t, const Block &, const StatsCollectingParams &, bool): Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=5, jobs=2). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af80b71 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af82f33 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000287ad950 7. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:35: DB::chooseJoinAlgorithm(std::shared_ptr&, std::shared_ptr const&, DB::Block const&, DB::Block const&, std::shared_ptr const&) @ 0x00000000294a6614 8. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1490: DB::(anonymous namespace)::buildQueryPlanForJoinNode(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000002947642f 9. ./build_docker/./src/Planner/PlannerJoinTree.cpp:0: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000002945f174 10. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x000000002942c986 11. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x00000000294261fb 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) @ 0x0000000029464fdb 13. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1795: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000002945d99d 14. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x000000002942c986 15. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x00000000294261fb 16. ./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) @ 0x0000000029464fdb 17. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1795: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000002945d99d 18. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x000000002942c986 19. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x00000000294261fb 20. ./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) @ 0x0000000029464fdb 21. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1795: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000002945d99d 22. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x000000002942c986 23. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x00000000294261fb 24. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000029421552 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1182: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3737e 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 27. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 28. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:07:32.590646 [ 20351 ] {8d73d9d2-011e-47bd-a151-f6a8a2cfc13e} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:46142) (comment: 01542_dictionary_load_exception_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:32.591070 [ 3722 ] {b6679844-e20c-45a6-a41d-8a307edce308} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:46192) (comment: 01542_dictionary_load_exception_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:32.599345 [ 20351 ] {8d73d9d2-011e-47bd-a151-f6a8a2cfc13e} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:32.599479 [ 3722 ] {b6679844-e20c-45a6-a41d-8a307edce308} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:32.691610 [ 20380 ] {bbcf4b32-df00-4dd0-90a4-3defa63131f6} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=5, jobs=2). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:46170) (comment: 02789_filesystem_cache_alignment.sh) (in query: SELECT count() FROM ( SELECT * FROM (SELECT * FROM ( SELECT cache_path, file_size, tupleElement(file_segment_range, 2) - tupleElement(file_segment_range, 1) + 1 as file_segment_size, formatReadableSize(file_size) as formatted_file_size, formatReadableSize(file_segment_size) as formatted_file_segment_size, tupleElement(file_segment_range, 2) as end_offset FROM ( SELECT arrayJoin(cache_paths) AS cache_path, local_path, remote_path, size as file_size FROM system.remote_data_paths WHERE endsWith(local_path, '.bin') ) AS data_paths INNER JOIN system.filesystem_cache_log AS cache_log ON data_paths.remote_path = cache_log.source_file_path WHERE query_id = '20490' )) AS cache_log INNER JOIN system.filesystem_cache AS cache ON cache_log.cache_path = cache.cache_path ) WHERE file_segment_size < file_size AND file_segment_range_end + 1 != file_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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af80b71 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af82f33 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000287ad950 7. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:35: DB::chooseJoinAlgorithm(std::shared_ptr&, std::shared_ptr const&, DB::Block const&, DB::Block const&, std::shared_ptr const&) @ 0x00000000294a6614 8. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1490: DB::(anonymous namespace)::buildQueryPlanForJoinNode(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000002947642f 9. ./build_docker/./src/Planner/PlannerJoinTree.cpp:0: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000002945f174 10. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x000000002942c986 11. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x00000000294261fb 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) @ 0x0000000029464fdb 13. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1795: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000002945d99d 14. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x000000002942c986 15. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x00000000294261fb 16. ./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) @ 0x0000000029464fdb 17. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1795: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000002945d99d 18. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x000000002942c986 19. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x00000000294261fb 20. ./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) @ 0x0000000029464fdb 21. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1795: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000002945d99d 22. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x000000002942c986 23. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x00000000294261fb 24. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000029421552 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1182: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3737e 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 27. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 28. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 2025.09.09 15:07:32.716945 [ 20380 ] {bbcf4b32-df00-4dd0-90a4-3defa63131f6} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=5, jobs=2). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af80b71 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af82f33 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000287ad950 7. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:35: DB::chooseJoinAlgorithm(std::shared_ptr&, std::shared_ptr const&, DB::Block const&, DB::Block const&, std::shared_ptr const&) @ 0x00000000294a6614 8. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1490: DB::(anonymous namespace)::buildQueryPlanForJoinNode(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000002947642f 9. ./build_docker/./src/Planner/PlannerJoinTree.cpp:0: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000002945f174 10. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x000000002942c986 11. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x00000000294261fb 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) @ 0x0000000029464fdb 13. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1795: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000002945d99d 14. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x000000002942c986 15. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x00000000294261fb 16. ./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) @ 0x0000000029464fdb 17. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1795: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000002945d99d 18. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x000000002942c986 19. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x00000000294261fb 20. ./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) @ 0x0000000029464fdb 21. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1795: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000002945d99d 22. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x000000002942c986 23. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x00000000294261fb 24. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000029421552 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1182: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3737e 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 27. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 28. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 2025.09.09 15:07:32.736065 [ 2898 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:07:32.739024 [ 2907 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:07:32.749407 [ 2879 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:07:33.047895 [ 3612 ] {4289e6ea-dd72-4e88-b9e5-e1e8dafa420e} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:46206) (comment: 01542_dictionary_load_exception_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:33.116159 [ 20338 ] {4cb87890-8438-4723-af23-5ba6d5a59666} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:46232) (comment: 01542_dictionary_load_exception_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:33.133257 [ 3612 ] {4289e6ea-dd72-4e88-b9e5-e1e8dafa420e} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:33.133357 [ 20881 ] {4168d74a-dae9-45d5-8d94-c78d80cdc68d} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:46216) (comment: 01542_dictionary_load_exception_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:33.133244 [ 20338 ] {4cb87890-8438-4723-af23-5ba6d5a59666} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:33.143012 [ 20881 ] {4168d74a-dae9-45d5-8d94-c78d80cdc68d} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:33.147353 [ 20343 ] {9997be21-66c9-4918-a159-ed925add9417} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:46238) (comment: 01542_dictionary_load_exception_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:33.150793 [ 20343 ] {9997be21-66c9-4918-a159-ed925add9417} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:33.174820 [ 20350 ] {5d44cc7c-22f1-4d87-87a6-44e045c6c1a9} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:46246) (comment: 01542_dictionary_load_exception_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:33.192099 [ 20350 ] {5d44cc7c-22f1-4d87-87a6-44e045c6c1a9} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:33.194688 [ 20345 ] {1b2b8305-0888-4707-82e5-abb009be96cb} executeQuery: Code: 42. DB::Exception: Number of arguments for function addressToLine doesn't match: passed 2, should be 1: In scope SELECT addressToLine(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT addressToLine(NULL, NULL);) 2025.09.09 15:07:33.202076 [ 20345 ] {1b2b8305-0888-4707-82e5-abb009be96cb} TCPHandler: Code: 42. DB::Exception: Number of arguments for function addressToLine doesn't match: passed 2, should be 1: In scope SELECT addressToLine(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:07:33.223848 [ 20882 ] {84fc7b89-4629-4c62-ae16-b1d48907f720} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:46220) (comment: 01542_dictionary_load_exception_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:33.230411 [ 20882 ] {84fc7b89-4629-4c62-ae16-b1d48907f720} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:33.274364 [ 20351 ] {5c4c6eb7-2833-408a-8c7c-7825b002550d} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:46250) (comment: 01542_dictionary_load_exception_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:33.276472 [ 20351 ] {5c4c6eb7-2833-408a-8c7c-7825b002550d} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:33.354077 [ 20345 ] {4ae845fe-3251-43d4-9308-730d2913ab60} executeQuery: Code: 42. DB::Exception: Number of arguments for function addressToLineWithInlines doesn't match: passed 2, should be 1: In scope SELECT addressToLineWithInlines(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT addressToLineWithInlines(NULL, NULL);) 2025.09.09 15:07:33.365560 [ 20345 ] {4ae845fe-3251-43d4-9308-730d2913ab60} TCPHandler: Code: 42. DB::Exception: Number of arguments for function addressToLineWithInlines doesn't match: passed 2, should be 1: In scope SELECT addressToLineWithInlines(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:07:33.373040 [ 2976 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:07:33.397718 [ 20355 ] {a4f3e5c9-3384-4fe0-bea1-ee2bba560ef9} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:46268) (comment: 01542_dictionary_load_exception_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:33.406254 [ 20355 ] {a4f3e5c9-3384-4fe0-bea1-ee2bba560ef9} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:33.406428 [ 20379 ] {b90d7851-8023-4be7-a216-0369aaedf6d0} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:46284) (comment: 01542_dictionary_load_exception_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:33.420999 [ 2687 ] {db14a723-c94d-4454-bda4-2ba7a9a34299} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:46296) (comment: 01542_dictionary_load_exception_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:33.432098 [ 2687 ] {db14a723-c94d-4454-bda4-2ba7a9a34299} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:33.451319 [ 20380 ] {8f98ab6c-53ea-4d6a-ab1e-6d74990ff66c} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:46292) (comment: 01542_dictionary_load_exception_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:33.458418 [ 20380 ] {8f98ab6c-53ea-4d6a-ab1e-6d74990ff66c} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:33.469229 [ 20345 ] {9ce95218-bc7f-4ee9-9b5d-4a984cc341c9} executeQuery: Code: 42. DB::Exception: Number of arguments for function addressToSymbol doesn't match: passed 2, should be 1: In scope SELECT addressToSymbol(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT addressToSymbol(NULL, NULL);) 2025.09.09 15:07:33.476792 [ 20345 ] {9ce95218-bc7f-4ee9-9b5d-4a984cc341c9} TCPHandler: Code: 42. DB::Exception: Number of arguments for function addressToSymbol doesn't match: passed 2, should be 1: In scope SELECT addressToSymbol(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:07:33.497324 [ 20379 ] {b90d7851-8023-4be7-a216-0369aaedf6d0} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:33.556440 [ 3722 ] {483009ba-2977-40cc-8de2-5ce87c49b500} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:46310) (comment: 01542_dictionary_load_exception_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:33.566290 [ 3722 ] {483009ba-2977-40cc-8de2-5ce87c49b500} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:33.740030 [ 2967 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:07:33.740723 [ 3002 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:07:33.751132 [ 3011 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:07:33.940359 [ 20881 ] {93676851-0a0e-403d-9e24-bcf21094da58} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:46316) (comment: 01542_dictionary_load_exception_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:33.942839 [ 20882 ] {f4611e59-1f77-429d-9361-b6d07491d59c} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:46330) (comment: 01542_dictionary_load_exception_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:33.950952 [ 20882 ] {f4611e59-1f77-429d-9361-b6d07491d59c} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:33.953642 [ 20881 ] {93676851-0a0e-403d-9e24-bcf21094da58} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:33.970204 [ 3612 ] {102a2839-2f46-4909-9539-956dcbbcf5fe} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:46314) (comment: 01542_dictionary_load_exception_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:33.973844 [ 3612 ] {102a2839-2f46-4909-9539-956dcbbcf5fe} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:33.986793 [ 20343 ] {b2a7aa2d-725b-473f-8f88-e3ee47d5d1f5} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:46352) (comment: 01542_dictionary_load_exception_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:33.994471 [ 20343 ] {b2a7aa2d-725b-473f-8f88-e3ee47d5d1f5} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:34.003493 [ 20338 ] {19b45113-bcf3-4628-8097-ab6462180a52} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:46340) (comment: 01542_dictionary_load_exception_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:34.005446 [ 20338 ] {19b45113-bcf3-4628-8097-ab6462180a52} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:34.030105 [ 20350 ] {6c750c2d-5873-421e-a32e-4f5d6ac8eadd} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:46364) (comment: 01542_dictionary_load_exception_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:34.031979 [ 20350 ] {6c750c2d-5873-421e-a32e-4f5d6ac8eadd} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:34.201843 [ 20351 ] {fdf2f3e6-07f9-421a-9b5d-f17f5de4362d} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:46374) (comment: 01542_dictionary_load_exception_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:34.203837 [ 20351 ] {fdf2f3e6-07f9-421a-9b5d-f17f5de4362d} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:34.343790 [ 20355 ] {0b4cce2e-76b9-47ee-9bfb-81be2ee74df4} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:46390) (comment: 01542_dictionary_load_exception_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:34.352115 [ 20355 ] {0b4cce2e-76b9-47ee-9bfb-81be2ee74df4} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:34.381648 [ 3038 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:07:34.388492 [ 20380 ] {bec4eaa0-cef0-4315-a3a1-afd43afc8862} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:46416) (comment: 01542_dictionary_load_exception_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:34.413408 [ 20380 ] {bec4eaa0-cef0-4315-a3a1-afd43afc8862} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:34.431170 [ 2687 ] {6613f514-922a-4077-8c0c-e718d446fff0} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:46432) (comment: 01542_dictionary_load_exception_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:34.434015 [ 2687 ] {6613f514-922a-4077-8c0c-e718d446fff0} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:34.445317 [ 20379 ] {60e99f28-be28-4f01-82c2-15b37295592c} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:46400) (comment: 01542_dictionary_load_exception_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:34.447842 [ 20379 ] {60e99f28-be28-4f01-82c2-15b37295592c} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:34.536925 [ 3722 ] {82e1f37d-5082-4f47-8ddc-8acbae7fc27c} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:46434) (comment: 01542_dictionary_load_exception_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:34.637912 [ 3722 ] {82e1f37d-5082-4f47-8ddc-8acbae7fc27c} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:34.741963 [ 3073 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:07:34.742295 [ 3090 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:07:34.755726 [ 3041 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:07:34.802962 [ 20355 ] {48d9aad3-79f8-474a-b6c5-9ca47c4797aa} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:46448) (comment: 01542_dictionary_load_exception_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:34.812230 [ 20355 ] {48d9aad3-79f8-474a-b6c5-9ca47c4797aa} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:34.831821 [ 20351 ] {1787852a-1e55-43d7-9d67-c65b6a7dfa35} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:46436) (comment: 01542_dictionary_load_exception_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:34.838442 [ 20351 ] {1787852a-1e55-43d7-9d67-c65b6a7dfa35} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:34.842423 [ 19252 ] {7ff0c863-f370-4d5e-b682-a74cd1408f36} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:46482) (comment: 01542_dictionary_load_exception_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:34.842453 [ 2687 ] {0aa8fe0b-51a1-4a31-b16d-04de768fea1b} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:46466) (comment: 01542_dictionary_load_exception_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:34.850602 [ 2687 ] {0aa8fe0b-51a1-4a31-b16d-04de768fea1b} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:34.850786 [ 19252 ] {7ff0c863-f370-4d5e-b682-a74cd1408f36} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:34.852941 [ 20379 ] {4627e19f-f2c6-4c75-a652-03286a289102} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:46454) (comment: 01542_dictionary_load_exception_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:34.855628 [ 20380 ] {82477d65-341f-4aec-bcd0-29d8a60f11eb} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:46460) (comment: 01542_dictionary_load_exception_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:34.875197 [ 20380 ] {82477d65-341f-4aec-bcd0-29d8a60f11eb} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:34.909563 [ 20379 ] {4627e19f-f2c6-4c75-a652-03286a289102} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:34.985811 [ 3464 ] {} test_0473czib.mt (37fd3cf2-879f-4934-ac8d-662471988a31): dropAllData: got exception removing parts from disk, removing successfully removed parts from memory. 2025.09.09 15:07:34.998101 [ 3464 ] {} DatabaseCatalog: Cannot drop table test_0473czib.mt (37fd3cf2-879f-4934-ac8d-662471988a31). 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af819ed 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80746 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000263a174e 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002c47c445 8. ./contrib/llvm-project/libcxx/include/vector:547: DB::MergeTreeData::clearPartsFromFilesystem(std::vector, std::allocator>> const&, bool, std::unordered_set, std::equal_to, std::allocator>*) @ 0x000000002c47a78e 9. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::dropAllData() @ 0x000000002c4862d9 10. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::dropTableFinally(DB::DatabaseCatalog::TableMarkedAsDropped const&) @ 0x00000000286c7c77 11. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: void std::__function::__policy_invoker::__call_impl, std::allocator>>)::$_0, void ()>>(std::__function::__policy_storage const*) @ 0x00000000286d9744 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000263a3ea5 13. ./contrib/llvm-project/libcxx/include/future:0: std::packaged_task::operator()() @ 0x000000001bba33ac 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7eaf0 15. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001af8a79f 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 18. asan_thread_start(void*) @ 0x000000000aa43059 19. ? @ 0x00007f35aab92ac3 20. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:07:35.120850 [ 3722 ] {288749fa-7961-4a2b-b16b-7dc8cf67e56c} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:46498) (comment: 01542_dictionary_load_exception_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:35.130814 [ 3722 ] {288749fa-7961-4a2b-b16b-7dc8cf67e56c} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:35.161758 [ 20355 ] {cdc244fb-e923-499e-8e60-60d44063c6ac} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:46512) (comment: 01542_dictionary_load_exception_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:35.179581 [ 20355 ] {cdc244fb-e923-499e-8e60-60d44063c6ac} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:35.275246 [ 20380 ] {1551fa37-c03a-4bf9-b497-250e574da22e} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:46534) (comment: 01542_dictionary_load_exception_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:35.282781 [ 20380 ] {1551fa37-c03a-4bf9-b497-250e574da22e} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:35.282951 [ 20351 ] {5180f3e4-10f9-467e-b075-f9866b1f440a} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:46528) (comment: 01542_dictionary_load_exception_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:35.294424 [ 20351 ] {5180f3e4-10f9-467e-b075-f9866b1f440a} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:35.304190 [ 20379 ] {5ee765a2-d320-4058-9528-4c862d33b2e9} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:46532) (comment: 01542_dictionary_load_exception_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:35.305924 [ 20379 ] {5ee765a2-d320-4058-9528-4c862d33b2e9} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:35.384400 [ 3119 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:07:35.603615 [ 20351 ] {122d3085-f997-4087-910a-3ab2e2df8053} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:46548) (comment: 01542_dictionary_load_exception_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:35.622724 [ 20351 ] {122d3085-f997-4087-910a-3ab2e2df8053} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:35.659876 [ 2687 ] {8f389c03-d9aa-41b6-976c-b11425c4d6c4} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:46544) (comment: 01542_dictionary_load_exception_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:35.662027 [ 2687 ] {8f389c03-d9aa-41b6-976c-b11425c4d6c4} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:35.729631 [ 20355 ] {8253a020-c35f-40e1-9219-27db9e12cf3a} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=790, jobs=750). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:46560) (comment: 01542_dictionary_load_exception_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af872f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af7b2d1 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af7c3f3 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d36920d 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000002d369e5f 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processOrdinaryQuery() @ 0x000000002d18af7b 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d17644a 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 15. asan_thread_start(void*) @ 0x000000000aa43059 16. ? @ 0x00007f35aab92ac3 17. ? @ 0x00007f35aac24850 2025.09.09 15:07:35.731735 [ 20355 ] {8253a020-c35f-40e1-9219-27db9e12cf3a} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=790, jobs=750). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af872f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af7b2d1 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af7c3f3 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d36920d 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000002d369e5f 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processOrdinaryQuery() @ 0x000000002d18af7b 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d17644a 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 15. asan_thread_start(void*) @ 0x000000000aa43059 16. ? @ 0x00007f35aab92ac3 17. ? @ 0x00007f35aac24850 2025.09.09 15:07:35.742878 [ 3722 ] {e615e4e2-69c7-4443-bf87-da25dbd5fee8} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:46606) (comment: 01542_dictionary_load_exception_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:35.743555 [ 3179 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:07:35.743934 [ 3153 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:07:35.751037 [ 3722 ] {e615e4e2-69c7-4443-bf87-da25dbd5fee8} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:35.753567 [ 20380 ] {38417c6a-7cf2-4cf4-a253-4f140b254a50} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:46592) (comment: 01542_dictionary_load_exception_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:35.757273 [ 3180 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:07:35.758005 [ 20380 ] {38417c6a-7cf2-4cf4-a253-4f140b254a50} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:35.775571 [ 20379 ] {0624498b-ebc0-420c-8187-f4eb8ef51f5b} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:46576) (comment: 01542_dictionary_load_exception_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:35.777648 [ 20379 ] {0624498b-ebc0-420c-8187-f4eb8ef51f5b} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:35.923572 [ 19252 ] {54591852-96ba-4f96-b92e-5c1702834f42} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:46616) (comment: 01542_dictionary_load_exception_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:35.929507 [ 19252 ] {54591852-96ba-4f96-b92e-5c1702834f42} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:36.003261 [ 20345 ] {364da5b5-0079-4635-95c0-d28c59fa9595} executeQuery: Code: 42. DB::Exception: Aggregate function anyLast_respect_nulls requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT anyLast_respect_nulls(NULL, NULL);) 2025.09.09 15:07:36.011676 [ 20345 ] {364da5b5-0079-4635-95c0-d28c59fa9595} TCPHandler: Code: 42. DB::Exception: Aggregate function anyLast_respect_nulls requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:07:36.017179 [ 20884 ] {e1036603-a963-4080-8e45-30b3f9091ed0} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:46640) (comment: 01542_dictionary_load_exception_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:36.049222 [ 20379 ] {8dddc81c-2fe7-4b58-a086-d79ffecec569} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:46662) (comment: 01542_dictionary_load_exception_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:36.049950 [ 20351 ] {516dbcac-2900-4d17-b4d0-1b44f363d6f4} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:46646) (comment: 01542_dictionary_load_exception_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:36.052205 [ 20379 ] {8dddc81c-2fe7-4b58-a086-d79ffecec569} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:36.070287 [ 20849 ] {84d97ad3-cdf6-408e-aa5a-d3c1965c9538} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:46630) (comment: 01542_dictionary_load_exception_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:36.072180 [ 20849 ] {84d97ad3-cdf6-408e-aa5a-d3c1965c9538} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:36.083234 [ 20884 ] {e1036603-a963-4080-8e45-30b3f9091ed0} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:36.161093 [ 20345 ] {54ce7fb6-ca43-4977-ac8d-db2b1ed87871} executeQuery: Code: 42. DB::Exception: Aggregate function any_respect_nulls requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT any_respect_nulls(NULL, NULL);) 2025.09.09 15:07:36.179331 [ 20351 ] {516dbcac-2900-4d17-b4d0-1b44f363d6f4} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:36.211091 [ 20345 ] {54ce7fb6-ca43-4977-ac8d-db2b1ed87871} TCPHandler: Code: 42. DB::Exception: Aggregate function any_respect_nulls requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:07:36.242811 [ 20355 ] {f3d6718d-0616-418f-bf88-aa48512b309c} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:46654) (comment: 01542_dictionary_load_exception_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:36.255739 [ 20355 ] {f3d6718d-0616-418f-bf88-aa48512b309c} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:36.391550 [ 2761 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:07:36.435573 [ 20345 ] {e26609fd-262c-456a-abab-760ed000a7e0} executeQuery: Code: 42. DB::Exception: Aggregate function any_respect_nulls requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT any_value_respect_nulls(NULL, NULL);) 2025.09.09 15:07:36.461030 [ 20345 ] {e26609fd-262c-456a-abab-760ed000a7e0} TCPHandler: Code: 42. DB::Exception: Aggregate function any_respect_nulls requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:07:36.581318 [ 20351 ] {08f3bee5-9dcd-4cfb-9558-d7647665ddb4} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:46680) (comment: 01542_dictionary_load_exception_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:36.598480 [ 20351 ] {08f3bee5-9dcd-4cfb-9558-d7647665ddb4} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:36.607176 [ 20380 ] {a79e81b9-24e7-4f17-beca-a52d2c51b727} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:46688) (comment: 01542_dictionary_load_exception_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:36.612629 [ 20379 ] {8bb637e8-f2b3-4847-ab10-8e092ebab9f6} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:46674) (comment: 01542_dictionary_load_exception_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:36.614258 [ 20380 ] {a79e81b9-24e7-4f17-beca-a52d2c51b727} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:36.624847 [ 20379 ] {8bb637e8-f2b3-4847-ab10-8e092ebab9f6} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:36.632532 [ 2687 ] {65d9dc2e-a2d8-4711-8f48-3e673b76605e} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:46708) (comment: 01542_dictionary_load_exception_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:36.637247 [ 2687 ] {65d9dc2e-a2d8-4711-8f48-3e673b76605e} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:36.657245 [ 20355 ] {1f8b62c8-3a31-445e-94fd-d408d60865ab} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:46692) (comment: 01542_dictionary_load_exception_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:36.657226 [ 3722 ] {190d8497-b173-4a99-a193-ef30adfd957a} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:46710) (comment: 01542_dictionary_load_exception_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:36.670546 [ 20355 ] {1f8b62c8-3a31-445e-94fd-d408d60865ab} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:36.670896 [ 3722 ] {190d8497-b173-4a99-a193-ef30adfd957a} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:36.747013 [ 2755 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:07:36.756252 [ 2744 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:07:36.762939 [ 2743 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:07:36.814258 [ 19252 ] {5addb7a4-76a5-4d41-9500-229f7f585fa0} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:46720) (comment: 01542_dictionary_load_exception_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:36.816084 [ 19252 ] {5addb7a4-76a5-4d41-9500-229f7f585fa0} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:36.998584 [ 2688 ] {65c17ba9-4c4d-4c37-9a78-e5e1bc1f754a} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:46744) (comment: 01542_dictionary_load_exception_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:37.000352 [ 2688 ] {65c17ba9-4c4d-4c37-9a78-e5e1bc1f754a} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:37.005086 [ 20884 ] {f8a2695a-135a-4f81-aa99-797f975524ae} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:46740) (comment: 01542_dictionary_load_exception_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:37.005617 [ 20849 ] {f1298d11-3358-411f-9ad0-6edac0214e75} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:46732) (comment: 01542_dictionary_load_exception_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:37.014587 [ 20849 ] {f1298d11-3358-411f-9ad0-6edac0214e75} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:37.046386 [ 20884 ] {f8a2695a-135a-4f81-aa99-797f975524ae} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:37.083751 [ 20355 ] {245895c2-359c-4e93-b672-61be57bdd139} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:46752) (comment: 01542_dictionary_load_exception_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:37.098667 [ 20355 ] {245895c2-359c-4e93-b672-61be57bdd139} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:37.138955 [ 2687 ] {de464af3-31ca-4ca2-a380-c3b0a64408ad} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:46766) (comment: 01542_dictionary_load_exception_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:37.170309 [ 2687 ] {de464af3-31ca-4ca2-a380-c3b0a64408ad} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:37.392516 [ 20355 ] {9f05bdb4-7901-4a12-8028-e8d32e5105e4} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:46780) (comment: 01542_dictionary_load_exception_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:37.393001 [ 2828 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:07:37.402242 [ 20355 ] {9f05bdb4-7901-4a12-8028-e8d32e5105e4} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:37.422368 [ 3461 ] {} ExternalDictionariesLoader: Could not load external dictionary 'b9456353-118f-4e69-ac1b-88d4f6a6e618', next update is scheduled at 2025-09-09 15:07:56: 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:07:37.442843 [ 20849 ] {18b4790e-8952-46f8-b04f-21dc80fdbaed} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:46786) (comment: 01542_dictionary_load_exception_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:37.444810 [ 20849 ] {18b4790e-8952-46f8-b04f-21dc80fdbaed} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:37.445284 [ 3722 ] {64d5c852-43c0-4373-addf-dc46ed8f4b67} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:46782) (comment: 01542_dictionary_load_exception_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:37.461373 [ 19252 ] {2095c211-ad39-4d8d-870a-f7d071104dc7} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:46784) (comment: 01542_dictionary_load_exception_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:37.469625 [ 3722 ] {64d5c852-43c0-4373-addf-dc46ed8f4b67} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:37.470257 [ 19252 ] {2095c211-ad39-4d8d-870a-f7d071104dc7} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:37.528836 [ 20884 ] {cf3c5c4c-b0ae-414f-a7d2-13fc40c2cecd} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:46798) (comment: 01542_dictionary_load_exception_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:37.569806 [ 20884 ] {cf3c5c4c-b0ae-414f-a7d2-13fc40c2cecd} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:37.618743 [ 2687 ] {2bf7464f-dfbc-437a-a959-5b21e7d21b2c} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:46792) (comment: 01542_dictionary_load_exception_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:37.626760 [ 2687 ] {2bf7464f-dfbc-437a-a959-5b21e7d21b2c} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:37.752144 [ 2886 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:07:37.759855 [ 2860 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:07:37.773280 [ 2812 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:07:37.792175 [ 2688 ] {2494adb0-ed02-43d0-a02c-0ca8b7e9e493} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:46808) (comment: 01542_dictionary_load_exception_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:37.803225 [ 2688 ] {2494adb0-ed02-43d0-a02c-0ca8b7e9e493} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:37.810809 [ 20355 ] {dd3bbf0b-e96b-437f-94c8-2205c3161f04} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:46818) (comment: 01542_dictionary_load_exception_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:37.812851 [ 20355 ] {dd3bbf0b-e96b-437f-94c8-2205c3161f04} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:37.847035 [ 19252 ] {7c1324a5-428f-43f8-a051-6e5ff335385b} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:46832) (comment: 01542_dictionary_load_exception_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:37.850400 [ 19252 ] {7c1324a5-428f-43f8-a051-6e5ff335385b} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:37.892172 [ 3722 ] {e168615c-06dd-4f1e-8314-bb1b5017e881} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:46826) (comment: 01542_dictionary_load_exception_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:37.902340 [ 3722 ] {e168615c-06dd-4f1e-8314-bb1b5017e881} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:38.018637 [ 20849 ] {41247c69-a4c0-449c-90d8-1420e204d763} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:46838) (comment: 01542_dictionary_load_exception_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:38.061790 [ 20884 ] {81293e25-99cb-4d66-bc1d-87110d030423} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:46840) (comment: 01542_dictionary_load_exception_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:38.070535 [ 20849 ] {41247c69-a4c0-449c-90d8-1420e204d763} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:38.090302 [ 20884 ] {81293e25-99cb-4d66-bc1d-87110d030423} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:38.386661 [ 2687 ] {53897250-694f-402c-bf15-e8e546aa091e} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:51888) (comment: 01542_dictionary_load_exception_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:38.391637 [ 2687 ] {53897250-694f-402c-bf15-e8e546aa091e} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:38.399093 [ 2932 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:07:38.407835 [ 20355 ] {ba520ab5-19f6-46bb-b974-584539fef566} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:51882) (comment: 01542_dictionary_load_exception_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:38.408592 [ 3722 ] {926fa958-8519-436c-bbce-a96e28101b41} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:51896) (comment: 01542_dictionary_load_exception_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:38.409589 [ 19252 ] {05b63348-ce29-4c2e-9b0f-893152913e83} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:51908) (comment: 01542_dictionary_load_exception_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:38.409692 [ 20355 ] {ba520ab5-19f6-46bb-b974-584539fef566} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:38.420099 [ 3722 ] {926fa958-8519-436c-bbce-a96e28101b41} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:38.422062 [ 19252 ] {05b63348-ce29-4c2e-9b0f-893152913e83} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:38.430299 [ 2688 ] {da99c420-f8ab-4df0-a965-9bb437c8b078} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:51920) (comment: 01542_dictionary_load_exception_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:38.458401 [ 2688 ] {da99c420-f8ab-4df0-a965-9bb437c8b078} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:38.490693 [ 20849 ] {77dedec5-7437-445a-b2ed-19c9ca2f2a0b} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:51932) (comment: 01542_dictionary_load_exception_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:38.498369 [ 20849 ] {77dedec5-7437-445a-b2ed-19c9ca2f2a0b} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:38.643357 [ 20884 ] {e645d833-b0ed-479f-935e-d1479fe929ee} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:51942) (comment: 01542_dictionary_load_exception_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:38.650272 [ 20884 ] {e645d833-b0ed-479f-935e-d1479fe929ee} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:38.658311 [ 3612 ] {e31c6409-9e9c-4a86-902c-53ca6c6f7cc5} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:51944) (comment: 01542_dictionary_load_exception_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:38.659882 [ 3612 ] {e31c6409-9e9c-4a86-902c-53ca6c6f7cc5} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:38.717674 [ 20881 ] {c207a668-a864-40b4-81c6-a7da89648b94} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:51952) (comment: 01542_dictionary_load_exception_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:38.719464 [ 20881 ] {c207a668-a864-40b4-81c6-a7da89648b94} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:38.760619 [ 2973 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:07:38.767239 [ 2969 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:07:38.776646 [ 2984 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:07:38.846698 [ 20355 ] {343208f5-ef23-4b2b-b1a8-fd721411e173} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:51966) (comment: 01542_dictionary_load_exception_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:38.848222 [ 20355 ] {343208f5-ef23-4b2b-b1a8-fd721411e173} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:38.885550 [ 2687 ] {5140890b-5955-4a36-ab3a-7c4e92fa7f71} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:51972) (comment: 01542_dictionary_load_exception_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:38.887994 [ 2687 ] {5140890b-5955-4a36-ab3a-7c4e92fa7f71} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:39.025255 [ 3722 ] {b5855012-fd55-4794-9eda-a6b3d257984c} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:51974) (comment: 01542_dictionary_load_exception_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:39.028435 [ 5770 ] {} test_0473czib.mt (37fd3cf2-879f-4934-ac8d-662471988a31): dropAllData: got exception removing parts from disk, removing successfully removed parts from memory. 2025.09.09 15:07:39.037278 [ 5770 ] {} DatabaseCatalog: Cannot drop table test_0473czib.mt (37fd3cf2-879f-4934-ac8d-662471988a31). Will retry later.: 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af819ed 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80746 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000263a174e 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002c47c445 8. ./contrib/llvm-project/libcxx/include/vector:547: DB::MergeTreeData::clearPartsFromFilesystem(std::vector, std::allocator>> const&, bool, std::unordered_set, std::equal_to, std::allocator>*) @ 0x000000002c47a78e 9. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::dropAllData() @ 0x000000002c4862d9 10. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::dropTableFinally(DB::DatabaseCatalog::TableMarkedAsDropped const&) @ 0x00000000286c7c77 11. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: void std::__function::__policy_invoker::__call_impl, std::allocator>>)::$_0, void ()>>(std::__function::__policy_storage const*) @ 0x00000000286d9744 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000263a3ea5 13. ./contrib/llvm-project/libcxx/include/future:0: std::packaged_task::operator()() @ 0x000000001bba33ac 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7eaf0 15. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001af8a79f 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 18. asan_thread_start(void*) @ 0x000000000aa43059 19. ? @ 0x00007f35aab92ac3 20. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:07:39.037365 [ 3722 ] {b5855012-fd55-4794-9eda-a6b3d257984c} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:39.143197 [ 20849 ] {23c1ac38-fe84-4a56-9784-ba00a0d482b6} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:51992) (comment: 01542_dictionary_load_exception_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:39.144845 [ 20849 ] {23c1ac38-fe84-4a56-9784-ba00a0d482b6} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:39.169874 [ 20882 ] {9dcc0871-44a2-422a-9141-46f4c8017c59} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:52012) (comment: 01542_dictionary_load_exception_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:39.178439 [ 20882 ] {9dcc0871-44a2-422a-9141-46f4c8017c59} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:39.179897 [ 2688 ] {154a1290-b36d-4ecd-acac-f2cafd74251f} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:51998) (comment: 01542_dictionary_load_exception_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:39.186355 [ 2688 ] {154a1290-b36d-4ecd-acac-f2cafd74251f} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:39.261088 [ 19252 ] {89ae0457-19c4-467f-a54f-cfb49da701e2} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:51986) (comment: 01542_dictionary_load_exception_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:39.262628 [ 19252 ] {89ae0457-19c4-467f-a54f-cfb49da701e2} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:39.312957 [ 20338 ] {223fbd1e-cc78-4512-bbed-87a8f88ffe72} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:52020) (comment: 01542_dictionary_load_exception_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:39.332705 [ 20338 ] {223fbd1e-cc78-4512-bbed-87a8f88ffe72} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:39.374447 [ 20343 ] {fc23d3bf-d675-4b60-b460-27a5632286ba} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:52026) (comment: 01542_dictionary_load_exception_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:39.394760 [ 20343 ] {fc23d3bf-d675-4b60-b460-27a5632286ba} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:39.404091 [ 3024 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:07:39.488301 [ 20849 ] {49c9e8ba-b7dd-482b-9f11-fb40cf942526} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:52048) (comment: 01542_dictionary_load_exception_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:39.489939 [ 20849 ] {49c9e8ba-b7dd-482b-9f11-fb40cf942526} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:39.561058 [ 3722 ] {32b0a0fd-4351-4978-b6de-77b1a856a03b} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:52038) (comment: 01542_dictionary_load_exception_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:39.574784 [ 3722 ] {32b0a0fd-4351-4978-b6de-77b1a856a03b} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:39.637420 [ 19252 ] {cc2062c7-c068-42c5-bb4b-a7b761f194a1} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:52060) (comment: 01542_dictionary_load_exception_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:39.638971 [ 20345 ] {eb4e0d20-2d2e-415e-84b0-31c95dae4f19} executeQuery: Code: 42. DB::Exception: Number of arguments for function arrayDistinct doesn't match: passed 2, should be 1: In scope SELECT arrayDistinct(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT arrayDistinct(NULL, NULL);) 2025.09.09 15:07:39.642352 [ 19252 ] {cc2062c7-c068-42c5-bb4b-a7b761f194a1} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:39.656822 [ 2688 ] {d9c4e4c1-ea4f-4214-81f8-63962c84b463} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:52066) (comment: 01542_dictionary_load_exception_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:39.661198 [ 20882 ] {3f303f03-038b-401a-b862-60971b6358f5} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:52082) (comment: 01542_dictionary_load_exception_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:39.666571 [ 2688 ] {d9c4e4c1-ea4f-4214-81f8-63962c84b463} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:39.674442 [ 20882 ] {3f303f03-038b-401a-b862-60971b6358f5} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:39.679429 [ 20345 ] {eb4e0d20-2d2e-415e-84b0-31c95dae4f19} TCPHandler: Code: 42. DB::Exception: Number of arguments for function arrayDistinct doesn't match: passed 2, should be 1: In scope SELECT arrayDistinct(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:07:39.779866 [ 3076 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:07:39.781193 [ 3086 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:07:39.783537 [ 3085 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:07:39.905236 [ 3722 ] {c1521f5d-5c36-430f-8e72-071e50270ffa} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:52110) (comment: 01542_dictionary_load_exception_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:39.907466 [ 3722 ] {c1521f5d-5c36-430f-8e72-071e50270ffa} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:39.952442 [ 20849 ] {e0879b99-3208-47bd-bc70-4e1c3e8388c9} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:52098) (comment: 01542_dictionary_load_exception_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:39.989485 [ 20849 ] {e0879b99-3208-47bd-bc70-4e1c3e8388c9} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:40.000600 [ 2688 ] {b7899767-ea20-4801-a9c2-42e12a39a361} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:52128) (comment: 01542_dictionary_load_exception_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:40.006623 [ 2688 ] {b7899767-ea20-4801-a9c2-42e12a39a361} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:40.098021 [ 19252 ] {b3ff43c6-3c75-4c69-8164-e673f3dff992} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:52120) (comment: 01542_dictionary_load_exception_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:40.110322 [ 19252 ] {b3ff43c6-3c75-4c69-8164-e673f3dff992} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:40.141264 [ 20345 ] {9a7d99f8-423b-4844-9985-5a0c240cb90a} executeQuery: Code: 42. DB::Exception: Number of arguments for function arrayEnumerate doesn't match: passed 2, should be 1: In scope SELECT arrayEnumerate(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT arrayEnumerate(NULL, NULL);) 2025.09.09 15:07:40.155932 [ 20338 ] {ea917705-7280-4a2d-991d-493227141cc7} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:52150) (comment: 01542_dictionary_load_exception_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:40.161568 [ 20338 ] {ea917705-7280-4a2d-991d-493227141cc7} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:40.178028 [ 20343 ] {31448f72-e1b4-43df-9cc1-f10fc71eed18} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:52166) (comment: 01542_dictionary_load_exception_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:40.180089 [ 20343 ] {31448f72-e1b4-43df-9cc1-f10fc71eed18} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:40.189308 [ 20882 ] {45380cff-58c9-4f17-902f-fd34b82bf9fb} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:52136) (comment: 01542_dictionary_load_exception_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:40.198403 [ 20882 ] {45380cff-58c9-4f17-902f-fd34b82bf9fb} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:40.211101 [ 20345 ] {9a7d99f8-423b-4844-9985-5a0c240cb90a} TCPHandler: Code: 42. DB::Exception: Number of arguments for function arrayEnumerate doesn't match: passed 2, should be 1: In scope SELECT arrayEnumerate(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:07:40.318144 [ 20849 ] {23eda602-d140-4907-ac5e-4fcf9d660887} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:52182) (comment: 01542_dictionary_load_exception_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:40.318800 [ 3722 ] {b9f91912-1a6a-4484-8e82-3c8e99c0376e} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:52180) (comment: 01542_dictionary_load_exception_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:40.319999 [ 20849 ] {23eda602-d140-4907-ac5e-4fcf9d660887} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:40.342434 [ 3722 ] {b9f91912-1a6a-4484-8e82-3c8e99c0376e} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:40.396770 [ 2688 ] {39e0dbaf-698f-40a5-9632-745b8b496e2e} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:52198) (comment: 01542_dictionary_load_exception_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:40.398510 [ 2688 ] {39e0dbaf-698f-40a5-9632-745b8b496e2e} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:40.405621 [ 3181 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:07:40.448180 [ 20882 ] {9365ba7e-8384-494e-be6c-7f1a5f556375} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:52204) (comment: 01542_dictionary_load_exception_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:40.454617 [ 20882 ] {9365ba7e-8384-494e-be6c-7f1a5f556375} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:40.468979 [ 19252 ] {84fc765a-9f95-4ea2-999b-b2e4ffc71bc3} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:52192) (comment: 01542_dictionary_load_exception_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:40.475166 [ 19252 ] {84fc765a-9f95-4ea2-999b-b2e4ffc71bc3} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:40.732627 [ 3722 ] {b8752071-3cbc-4581-add5-83efaa129b67} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:52206) (comment: 01542_dictionary_load_exception_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:40.754109 [ 3722 ] {b8752071-3cbc-4581-add5-83efaa129b67} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:40.781518 [ 3156 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:07:40.784230 [ 3202 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:07:40.784877 [ 3238 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:07:40.863565 [ 19252 ] {30611387-f245-4421-820c-762d78c5eb50} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:52210) (comment: 01542_dictionary_load_exception_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:40.884466 [ 20882 ] {afdee637-1e58-4e30-bb1f-e2dab2c044ac} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:52254) (comment: 01542_dictionary_load_exception_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:40.891978 [ 20882 ] {afdee637-1e58-4e30-bb1f-e2dab2c044ac} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:40.900540 [ 20849 ] {258b6810-7ead-48bf-8195-4bc618e3228a} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:52224) (comment: 01542_dictionary_load_exception_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:40.904818 [ 19252 ] {30611387-f245-4421-820c-762d78c5eb50} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:40.910502 [ 20849 ] {258b6810-7ead-48bf-8195-4bc618e3228a} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:41.005841 [ 20338 ] {49dc057d-6cba-4c6e-9e40-eb2b357089f7} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:52266) (comment: 01542_dictionary_load_exception_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:41.013815 [ 20338 ] {49dc057d-6cba-4c6e-9e40-eb2b357089f7} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:41.023446 [ 2688 ] {fc992fea-91e8-45d0-ada5-daaeb87426aa} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:52238) (comment: 01542_dictionary_load_exception_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:41.027329 [ 2688 ] {fc992fea-91e8-45d0-ada5-daaeb87426aa} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:41.067332 [ 20343 ] {5445bdba-5b1e-4ffd-b3a2-05f9af97944d} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:52276) (comment: 01542_dictionary_load_exception_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:41.081763 [ 20343 ] {5445bdba-5b1e-4ffd-b3a2-05f9af97944d} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:41.142012 [ 20350 ] {c73d0218-d3e8-4526-870a-dee28a618346} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:52294) (comment: 01542_dictionary_load_exception_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:41.143751 [ 20350 ] {c73d0218-d3e8-4526-870a-dee28a618346} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:41.204988 [ 20351 ] {e4a355fd-d458-4adf-b0e5-8031e6c21459} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:52310) (comment: 01542_dictionary_load_exception_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:41.205886 [ 3722 ] {9fe927f6-13c9-4a9c-81fd-4e2e6640fe9e} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:52284) (comment: 01542_dictionary_load_exception_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:41.210333 [ 3722 ] {9fe927f6-13c9-4a9c-81fd-4e2e6640fe9e} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:41.214342 [ 20351 ] {e4a355fd-d458-4adf-b0e5-8031e6c21459} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:41.303266 [ 20379 ] {b8be0e50-8af6-46a2-82e8-8ff2868d08a8} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:52316) (comment: 01542_dictionary_load_exception_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:41.310496 [ 20379 ] {b8be0e50-8af6-46a2-82e8-8ff2868d08a8} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:41.391132 [ 20380 ] {21c2cca5-e254-45ac-afa2-3cfc9d25b67a} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:52332) (comment: 01542_dictionary_load_exception_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:41.392909 [ 20380 ] {21c2cca5-e254-45ac-afa2-3cfc9d25b67a} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:41.408229 [ 2744 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:07:41.661311 [ 20350 ] {c5e6b271-c74c-4c68-a775-b6db1cdb6872} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:52346) (comment: 01542_dictionary_load_exception_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:41.669381 [ 20350 ] {c5e6b271-c74c-4c68-a775-b6db1cdb6872} TCPHandler: Can't send logs to client: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::1]:9000 -> [::1]:52346). (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 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&&) @ 0x000000001b0b7a5f 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:169: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000001b0bada2 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:201: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000002cf09bf7 5. ./src/IO/WriteBuffer.h:66: DB::TCPHandler::sendLogData(DB::Block const&) @ 0x000000002d1a9beb 6. ./contrib/llvm-project/libcxx/include/__hash_table:1473: DB::TCPHandler::sendLogs() @ 0x000000002d18db59 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d176902 8. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 12. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 13. asan_thread_start(void*) @ 0x000000000aa43059 14. ? @ 0x00007f35aab92ac3 15. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:07:41.670261 [ 20350 ] {c5e6b271-c74c-4c68-a775-b6db1cdb6872} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:41.671305 [ 20351 ] {d988a197-97d1-4283-89a9-a4b3ffefa2d8} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:52348) (comment: 01542_dictionary_load_exception_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:41.672534 [ 20350 ] {c5e6b271-c74c-4c68-a775-b6db1cdb6872} TCPHandler: Client has gone away. 2025.09.09 15:07:41.678486 [ 20351 ] {d988a197-97d1-4283-89a9-a4b3ffefa2d8} TCPHandler: Can't send logs to client: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::1]:9000 -> [::1]:52348). (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 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&&) @ 0x000000001b0b7a5f 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:169: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000001b0bada2 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:201: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000002cf09bf7 5. ./src/IO/WriteBuffer.h:66: DB::TCPHandler::sendLogData(DB::Block const&) @ 0x000000002d1a9beb 6. ./contrib/llvm-project/libcxx/include/__hash_table:1473: DB::TCPHandler::sendLogs() @ 0x000000002d18db59 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d176902 8. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 12. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 13. asan_thread_start(void*) @ 0x000000000aa43059 14. ? @ 0x00007f35aab92ac3 15. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:07:41.683038 [ 20351 ] {d988a197-97d1-4283-89a9-a4b3ffefa2d8} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:41.687496 [ 20351 ] {d988a197-97d1-4283-89a9-a4b3ffefa2d8} TCPHandler: Client has gone away. 2025.09.09 15:07:41.699686 [ 20379 ] {adcaa844-81f5-4758-bc11-99aff81eafc8} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:52352) (comment: 01542_dictionary_load_exception_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:41.702287 [ 20379 ] {adcaa844-81f5-4758-bc11-99aff81eafc8} TCPHandler: Can't send logs to client: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::1]:9000 -> [::1]:52352). (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 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&&) @ 0x000000001b0b7a5f 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:169: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000001b0bada2 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:201: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000002cf09bf7 5. ./src/IO/WriteBuffer.h:66: DB::TCPHandler::sendLogData(DB::Block const&) @ 0x000000002d1a9beb 6. ./contrib/llvm-project/libcxx/include/__hash_table:1473: DB::TCPHandler::sendLogs() @ 0x000000002d18db59 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d176902 8. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 12. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 13. asan_thread_start(void*) @ 0x000000000aa43059 14. ? @ 0x00007f35aab92ac3 15. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:07:41.703252 [ 20379 ] {adcaa844-81f5-4758-bc11-99aff81eafc8} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:41.704624 [ 20379 ] {adcaa844-81f5-4758-bc11-99aff81eafc8} TCPHandler: Client has gone away. 2025.09.09 15:07:41.738796 [ 20355 ] {162e34e8-527d-4784-9577-6c8d2e7adaa8} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:52366) (comment: 01542_dictionary_load_exception_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:41.743066 [ 20355 ] {162e34e8-527d-4784-9577-6c8d2e7adaa8} TCPHandler: Can't send logs to client: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::1]:9000 -> [::1]:52366). (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 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&&) @ 0x000000001b0b7a5f 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:169: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000001b0bada2 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:201: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000002cf09bf7 5. ./src/IO/WriteBuffer.h:66: DB::TCPHandler::sendLogData(DB::Block const&) @ 0x000000002d1a9beb 6. ./contrib/llvm-project/libcxx/include/__hash_table:1473: DB::TCPHandler::sendLogs() @ 0x000000002d18db59 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d176902 8. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 12. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 13. asan_thread_start(void*) @ 0x000000000aa43059 14. ? @ 0x00007f35aab92ac3 15. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:07:41.744849 [ 20355 ] {162e34e8-527d-4784-9577-6c8d2e7adaa8} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:41.749842 [ 20355 ] {162e34e8-527d-4784-9577-6c8d2e7adaa8} TCPHandler: Client has gone away. 2025.09.09 15:07:41.783159 [ 3058 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:07:41.784865 [ 20380 ] {7a44d498-f1c5-4a5f-b8fa-5fdf81156b0c} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:52376) (comment: 01542_dictionary_load_exception_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:41.786314 [ 2798 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:07:41.786711 [ 2813 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:07:41.788587 [ 20380 ] {7a44d498-f1c5-4a5f-b8fa-5fdf81156b0c} TCPHandler: Can't send logs to client: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::1]:9000 -> [::1]:52376). (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 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&&) @ 0x000000001b0b7a5f 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:169: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000001b0bada2 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:201: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000002cf09bf7 5. ./src/IO/WriteBuffer.h:66: DB::TCPHandler::sendLogData(DB::Block const&) @ 0x000000002d1a9beb 6. ./contrib/llvm-project/libcxx/include/__hash_table:1473: DB::TCPHandler::sendLogs() @ 0x000000002d18db59 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d176902 8. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 12. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 13. asan_thread_start(void*) @ 0x000000000aa43059 14. ? @ 0x00007f35aab92ac3 15. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:07:41.790342 [ 20380 ] {7a44d498-f1c5-4a5f-b8fa-5fdf81156b0c} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:41.792811 [ 20380 ] {7a44d498-f1c5-4a5f-b8fa-5fdf81156b0c} TCPHandler: Client has gone away. 2025.09.09 15:07:41.852707 [ 20345 ] {a55aa279-83f8-43fd-888c-ed5156a8c917} executeQuery: Code: 42. DB::Exception: Number of arguments for function arrayFlatten doesn't match: passed 2, should be 1: In scope SELECT arrayFlatten(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT arrayFlatten(NULL, NULL);) 2025.09.09 15:07:41.856075 [ 20345 ] {a55aa279-83f8-43fd-888c-ed5156a8c917} TCPHandler: Code: 42. DB::Exception: Number of arguments for function arrayFlatten doesn't match: passed 2, should be 1: In scope SELECT arrayFlatten(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:07:41.896898 [ 20345 ] {1af7b645-1d46-44cb-95c2-6a66f75f6e8b} executeQuery: Code: 35. DB::Exception: Function arrayFold requires as arguments a lambda function, at least one array and an accumulator: In scope SELECT arrayFold(NULL, NULL). (TOO_FEW_ARGUMENTS_FOR_FUNCTION) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT arrayFold(NULL, NULL);) 2025.09.09 15:07:41.900434 [ 20345 ] {1af7b645-1d46-44cb-95c2-6a66f75f6e8b} TCPHandler: Code: 35. DB::Exception: Function arrayFold requires as arguments a lambda function, at least one array and an accumulator: In scope SELECT arrayFold(NULL, NULL). (TOO_FEW_ARGUMENTS_FOR_FUNCTION) 2025.09.09 15:07:42.134293 [ 2827 ] {} test_3.part_log_profile_events_r2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.09.09 15:07:42.136037 [ 2856 ] {} test_3.part_header_r2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.09.09 15:07:42.138458 [ 2837 ] {} test_3.part_log_profile_events_r1 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.09.09 15:07:42.139436 [ 2815 ] {} test_3.test_03217_merge_replica_2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.09.09 15:07:42.140207 [ 2873 ] {} test_3.src (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.09.09 15:07:42.141304 [ 2808 ] {} test_3.test_03217_merge_replica_1 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.09.09 15:07:42.142350 [ 2851 ] {} test_15.primary_key (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.09.09 15:07:42.143657 [ 2878 ] {} test_1.order_by_all (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.09.09 15:07:42.144608 [ 2875 ] {} test_3.part_header_r2 (ccbf4dd0-4073-493b-966a-233c0c02c225): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/00814_replicated_minimalistic_part_header_zookeeper_test_3/test_00814/part_header/s1/replicas/2r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:07:42.145321 [ 2876 ] {} test_15.primary_key (b9a7fafa-043d-4b0b-9528-df8e4980f529): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_15/test_00215/primary_key/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:07:42.146060 [ 2886 ] {} test_3.src (a9587bc6-09b3-4b5a-81da-b7c2446903c9): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_3/03008_deduplication_remote_insert_select/src/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:07:42.146091 [ 2892 ] {} test_3.part_header_r2 (ccbf4dd0-4073-493b-966a-233c0c02c225): 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. ./contrib/llvm-project/libcxx/include/string:1499: _ZN12Coordination9ExceptionC2IRA16_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x000000002e65bfe6 3. ./src/Common/ZooKeeper/IKeeper.h:0: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x000000002e6c2259 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1437: Coordination::ZooKeeper::list(String const&, Coordination::ListRequestType, std::function, std::shared_ptr>) @ 0x000000002e6caac6 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002e5e9637 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:299: zkutil::ZooKeeper::getChildrenImpl(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000002e5e8bfa 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:372: zkutil::ZooKeeper::tryGetChildrenWatch(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000002e5ea588 8. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:57: zkutil::ZooKeeper::getChildrenWatch(String const&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000002e5ea43b 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:914: DB::ReplicatedMergeTreeQueue::updateMutations(std::shared_ptr, std::shared_ptr>) @ 0x000000002ca8268c 10. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3622: DB::StorageReplicatedMergeTree::mutationsUpdatingTask() @ 0x000000002baf70bc 11. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 13. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 16. asan_thread_start(void*) @ 0x000000000aa43059 17. ? @ 0x00007f35aab92ac3 18. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:07:42.146490 [ 2846 ] {} test_3.part_log_profile_events_r1 (d2579ae8-cbf6-4e32-8d68-3aedfa4d5aba): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_3/test_02378/part_log_profile_events/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:07:42.146632 [ 2862 ] {} test_15.primary_key (b9a7fafa-043d-4b0b-9528-df8e4980f529): 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. ./contrib/llvm-project/libcxx/include/string:1499: _ZN12Coordination9ExceptionC2IRA16_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x000000002e65bfe6 3. ./src/Common/ZooKeeper/IKeeper.h:0: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x000000002e6c2259 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1437: Coordination::ZooKeeper::list(String const&, Coordination::ListRequestType, std::function, std::shared_ptr>) @ 0x000000002e6caac6 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002e5e9637 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:299: zkutil::ZooKeeper::getChildrenImpl(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000002e5e8bfa 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:372: zkutil::ZooKeeper::tryGetChildrenWatch(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000002e5ea588 8. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:57: zkutil::ZooKeeper::getChildrenWatch(String const&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000002e5ea43b 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:914: DB::ReplicatedMergeTreeQueue::updateMutations(std::shared_ptr, std::shared_ptr>) @ 0x000000002ca8268c 10. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3622: DB::StorageReplicatedMergeTree::mutationsUpdatingTask() @ 0x000000002baf70bc 11. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 13. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 16. asan_thread_start(void*) @ 0x000000000aa43059 17. ? @ 0x00007f35aab92ac3 18. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:07:42.146759 [ 2849 ] {} test_3.part_log_profile_events_r2 (c6c145b3-8dfa-456b-a838-7d32ade90493): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_3/test_02378/part_log_profile_events/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:07:42.147206 [ 2860 ] {} test_3.src (a9587bc6-09b3-4b5a-81da-b7c2446903c9): 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. ./contrib/llvm-project/libcxx/include/string:1499: _ZN12Coordination9ExceptionC2IRA16_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x000000002e65bfe6 3. ./src/Common/ZooKeeper/IKeeper.h:0: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x000000002e6c2259 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1437: Coordination::ZooKeeper::list(String const&, Coordination::ListRequestType, std::function, std::shared_ptr>) @ 0x000000002e6caac6 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002e5e9637 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:299: zkutil::ZooKeeper::getChildrenImpl(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000002e5e8bfa 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:372: zkutil::ZooKeeper::tryGetChildrenWatch(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000002e5ea588 8. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:57: zkutil::ZooKeeper::getChildrenWatch(String const&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000002e5ea43b 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:914: DB::ReplicatedMergeTreeQueue::updateMutations(std::shared_ptr, std::shared_ptr>) @ 0x000000002ca8268c 10. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3622: DB::StorageReplicatedMergeTree::mutationsUpdatingTask() @ 0x000000002baf70bc 11. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 13. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 16. asan_thread_start(void*) @ 0x000000000aa43059 17. ? @ 0x00007f35aab92ac3 18. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:07:42.147996 [ 2892 ] {} test_3.test_03217_merge_replica_1 (558cd764-871b-4cdb-bd3d-87bfe9d01bf6): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_3/test_03217_merge_replica/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:07:42.148152 [ 2857 ] {} test_3.part_log_profile_events_r1 (d2579ae8-cbf6-4e32-8d68-3aedfa4d5aba): 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. ./contrib/llvm-project/libcxx/include/string:1499: _ZN12Coordination9ExceptionC2IRA16_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x000000002e65bfe6 3. ./src/Common/ZooKeeper/IKeeper.h:0: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x000000002e6c2259 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1437: Coordination::ZooKeeper::list(String const&, Coordination::ListRequestType, std::function, std::shared_ptr>) @ 0x000000002e6caac6 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002e5e9637 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:299: zkutil::ZooKeeper::getChildrenImpl(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000002e5e8bfa 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:372: zkutil::ZooKeeper::tryGetChildrenWatch(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000002e5ea588 8. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:57: zkutil::ZooKeeper::getChildrenWatch(String const&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000002e5ea43b 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:914: DB::ReplicatedMergeTreeQueue::updateMutations(std::shared_ptr, std::shared_ptr>) @ 0x000000002ca8268c 10. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3622: DB::StorageReplicatedMergeTree::mutationsUpdatingTask() @ 0x000000002baf70bc 11. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 13. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 16. asan_thread_start(void*) @ 0x000000000aa43059 17. ? @ 0x00007f35aab92ac3 18. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:07:42.148493 [ 2863 ] {} test_3.test_03217_merge_replica_2 (84f84548-349b-4925-ab55-cc31c8bb600b): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_3/test_03217_merge_replica/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:07:42.148679 [ 2876 ] {} test_3.part_log_profile_events_r2 (c6c145b3-8dfa-456b-a838-7d32ade90493): 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. ./contrib/llvm-project/libcxx/include/string:1499: _ZN12Coordination9ExceptionC2IRA16_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x000000002e65bfe6 3. ./src/Common/ZooKeeper/IKeeper.h:0: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x000000002e6c2259 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1437: Coordination::ZooKeeper::list(String const&, Coordination::ListRequestType, std::function, std::shared_ptr>) @ 0x000000002e6caac6 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002e5e9637 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:299: zkutil::ZooKeeper::getChildrenImpl(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000002e5e8bfa 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:372: zkutil::ZooKeeper::tryGetChildrenWatch(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000002e5ea588 8. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:57: zkutil::ZooKeeper::getChildrenWatch(String const&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000002e5ea43b 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:914: DB::ReplicatedMergeTreeQueue::updateMutations(std::shared_ptr, std::shared_ptr>) @ 0x000000002ca8268c 10. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3622: DB::StorageReplicatedMergeTree::mutationsUpdatingTask() @ 0x000000002baf70bc 11. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 13. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 16. asan_thread_start(void*) @ 0x000000000aa43059 17. ? @ 0x00007f35aab92ac3 18. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:07:42.149609 [ 2852 ] {} test_3.test_03217_merge_replica_1 (558cd764-871b-4cdb-bd3d-87bfe9d01bf6): 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. ./contrib/llvm-project/libcxx/include/string:1499: _ZN12Coordination9ExceptionC2IRA16_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x000000002e65bfe6 3. ./src/Common/ZooKeeper/IKeeper.h:0: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x000000002e6c2259 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1437: Coordination::ZooKeeper::list(String const&, Coordination::ListRequestType, std::function, std::shared_ptr>) @ 0x000000002e6caac6 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002e5e9637 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:299: zkutil::ZooKeeper::getChildrenImpl(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000002e5e8bfa 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:372: zkutil::ZooKeeper::tryGetChildrenWatch(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000002e5ea588 8. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:57: zkutil::ZooKeeper::getChildrenWatch(String const&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000002e5ea43b 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:914: DB::ReplicatedMergeTreeQueue::updateMutations(std::shared_ptr, std::shared_ptr>) @ 0x000000002ca8268c 10. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3622: DB::StorageReplicatedMergeTree::mutationsUpdatingTask() @ 0x000000002baf70bc 11. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 13. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 16. asan_thread_start(void*) @ 0x000000000aa43059 17. ? @ 0x00007f35aab92ac3 18. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:07:42.149905 [ 2888 ] {} test_1.order_by_all (a211317f-15a5-4e41-9466-f0e3dc49fa7b): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_1/test_03210/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:07:42.150574 [ 2846 ] {} test_3.test_03217_merge_replica_2 (84f84548-349b-4925-ab55-cc31c8bb600b): 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. ./contrib/llvm-project/libcxx/include/string:1499: _ZN12Coordination9ExceptionC2IRA16_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x000000002e65bfe6 3. ./src/Common/ZooKeeper/IKeeper.h:0: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x000000002e6c2259 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1437: Coordination::ZooKeeper::list(String const&, Coordination::ListRequestType, std::function, std::shared_ptr>) @ 0x000000002e6caac6 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002e5e9637 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:299: zkutil::ZooKeeper::getChildrenImpl(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000002e5e8bfa 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:372: zkutil::ZooKeeper::tryGetChildrenWatch(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000002e5ea588 8. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:57: zkutil::ZooKeeper::getChildrenWatch(String const&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000002e5ea43b 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:914: DB::ReplicatedMergeTreeQueue::updateMutations(std::shared_ptr, std::shared_ptr>) @ 0x000000002ca8268c 10. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3622: DB::StorageReplicatedMergeTree::mutationsUpdatingTask() @ 0x000000002baf70bc 11. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 13. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 16. asan_thread_start(void*) @ 0x000000000aa43059 17. ? @ 0x00007f35aab92ac3 18. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:07:42.151404 [ 2847 ] {} test_1.order_by_all (a211317f-15a5-4e41-9466-f0e3dc49fa7b): 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. ./contrib/llvm-project/libcxx/include/string:1499: _ZN12Coordination9ExceptionC2IRA16_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x000000002e65bfe6 3. ./src/Common/ZooKeeper/IKeeper.h:0: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x000000002e6c2259 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1437: Coordination::ZooKeeper::list(String const&, Coordination::ListRequestType, std::function, std::shared_ptr>) @ 0x000000002e6caac6 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002e5e9637 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:299: zkutil::ZooKeeper::getChildrenImpl(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000002e5e8bfa 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:372: zkutil::ZooKeeper::tryGetChildrenWatch(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000002e5ea588 8. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:57: zkutil::ZooKeeper::getChildrenWatch(String const&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000002e5ea43b 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:914: DB::ReplicatedMergeTreeQueue::updateMutations(std::shared_ptr, std::shared_ptr>) @ 0x000000002ca8268c 10. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3622: DB::StorageReplicatedMergeTree::mutationsUpdatingTask() @ 0x000000002baf70bc 11. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 13. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 16. asan_thread_start(void*) @ 0x000000000aa43059 17. ? @ 0x00007f35aab92ac3 18. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:07:42.158422 [ 2803 ] {} test_3.part_header_r1 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.09.09 15:07:42.158509 [ 2834 ] {} test_3.part_header_r1 (ReplicatedMergeTreeCleanupThread): void DB::ReplicatedMergeTreeCleanupThread::run(): Code: 999. Coordination::Exception: Session expired. (KEEPER_EXCEPTION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. ./contrib/llvm-project/libcxx/include/string:1499: _ZN12Coordination9ExceptionC2IRA16_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x000000002e65bfe6 3. ./src/Common/ZooKeeper/IKeeper.h:0: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x000000002e6c2259 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1365: Coordination::ZooKeeper::exists(String const&, std::function, std::shared_ptr>) @ 0x000000002e6c8872 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002e5f1235 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002e5f076a 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:598: zkutil::ZooKeeper::existsWatch(String const&, Coordination::Stat*, std::function) @ 0x000000002e5f16a2 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002e5ebc63 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:203: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x000000002ca16d1a 10. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x000000002ca15340 11. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:50: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x000000002ca13666 12. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 14. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:07:42.167054 [ 2848 ] {} test_3.part_header_r1 (badd489f-7d85-4dd7-8882-42d31f43e543): 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. ./contrib/llvm-project/libcxx/include/string:1499: _ZN12Coordination9ExceptionC2IRA16_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x000000002e65bfe6 3. ./src/Common/ZooKeeper/IKeeper.h:0: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x000000002e6c2259 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1437: Coordination::ZooKeeper::list(String const&, Coordination::ListRequestType, std::function, std::shared_ptr>) @ 0x000000002e6caac6 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002e5e9637 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:299: zkutil::ZooKeeper::getChildrenImpl(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000002e5e8bfa 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:372: zkutil::ZooKeeper::tryGetChildrenWatch(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000002e5ea588 8. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:57: zkutil::ZooKeeper::getChildrenWatch(String const&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000002e5ea43b 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:914: DB::ReplicatedMergeTreeQueue::updateMutations(std::shared_ptr, std::shared_ptr>) @ 0x000000002ca8268c 10. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3622: DB::StorageReplicatedMergeTree::mutationsUpdatingTask() @ 0x000000002baf70bc 11. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 13. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 16. asan_thread_start(void*) @ 0x000000000aa43059 17. ? @ 0x00007f35aab92ac3 18. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:07:42.179202 [ 20350 ] {d03e4620-956b-40f3-a97a-9996a363c0c3} executeQuery: Code: 62. DB::Exception: Cannot TRUNCATE dictionary. (SYNTAX_ERROR) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:52388) (comment: 01542_dictionary_load_exception_race.sh) (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aac868e 4. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:262: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x00000000291f1adc 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>>>&) @ 0x00000000291f510c 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:361: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000291edc97 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x00000000291ebf11 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x00000000291eb7ed 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b382fc 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 15:07:42.181534 [ 20345 ] {1d618eb5-2e8f-44a0-ada1-80babe276105} executeQuery: Code: 42. DB::Exception: Number of arguments for function arrayJoin doesn't match: passed 2, should be 1: In scope SELECT arrayJoin(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT arrayJoin(NULL, NULL);) 2025.09.09 15:07:42.183414 [ 20350 ] {d03e4620-956b-40f3-a97a-9996a363c0c3} 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aac868e 4. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:262: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x00000000291f1adc 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>>>&) @ 0x00000000291f510c 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:361: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000291edc97 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x00000000291ebf11 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x00000000291eb7ed 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b382fc 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 15:07:42.190441 [ 20345 ] {1d618eb5-2e8f-44a0-ada1-80babe276105} TCPHandler: Code: 42. DB::Exception: Number of arguments for function arrayJoin doesn't match: passed 2, should be 1: In scope SELECT arrayJoin(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:07:42.200120 [ 2861 ] {} test_3.part_header_r2 (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. ./contrib/llvm-project/libcxx/include/string:1499: _ZN12Coordination9ExceptionC2IRA41_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x000000002cb2daa6 3. ./src/Common/ZooKeeper/IKeeper.h:509: _ZN12Coordination9Exception11fromMessageIRA41_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEES0_NS_5ErrorEOS5_ @ 0x000000002e6d1195 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1654: Coordination::ZooKeeper::maybeInjectSendFault() @ 0x000000002e6c26aa 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:0: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x000000002e6c1f3d 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1437: Coordination::ZooKeeper::list(String const&, Coordination::ListRequestType, std::function, std::shared_ptr>) @ 0x000000002e6caac6 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002e5e9637 8. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:299: zkutil::ZooKeeper::getChildrenImpl(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000002e5e8bfa 9. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:372: zkutil::ZooKeeper::tryGetChildrenWatch(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000002e5ea588 10. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:346: zkutil::ZooKeeper::tryGetChildren(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr const&, Coordination::ListRequestType) @ 0x000000002e5e9d09 11. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:514: DB::ReplicatedMergeTreeCleanupThread::getBlocksSortedByTime(String const&, zkutil::ZooKeeper&, std::vector>&, std::map, std::less, std::allocator>>>&) @ 0x000000002ca25d67 12. ./contrib/llvm-project/libcxx/include/vector:553: DB::ReplicatedMergeTreeCleanupThread::clearOldBlocks(String const&, unsigned long, unsigned long, std::map, std::less, std::allocator>>>&) @ 0x000000002ca1d797 13. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x000000002ca153d0 14. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:50: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x000000002ca13666 15. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 17. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 20. asan_thread_start(void*) @ 0x000000000aa43059 21. ? @ 0x00007f35aab92ac3 22. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:07:42.203773 [ 3429 ] {} virtual void DB::ServerAsynchronousMetrics::updateImpl(TimePoint, TimePoint, bool, bool, AsynchronousMetricValues &): Cannot get replica delay for table: test_3.test_03217_merge_replica_2: Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_3/test_03217_merge_replica/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:7164: DB::StorageReplicatedMergeTree::getReplicaDelays(long&, long&) @ 0x000000002bb8386b 6. ./build_docker/./src/Interpreters/ServerAsynchronousMetrics.cpp:360: DB::ServerAsynchronousMetrics::updateImpl(std::chrono::time_point>>, std::chrono::time_point>>, bool, bool, std::unordered_map, std::equal_to, std::allocator>>&) @ 0x0000000029635fc0 7. ./src/Common/Stopwatch.h:72: DB::AsynchronousMetrics::update(std::chrono::time_point>>, bool) @ 0x000000001b0591cd 8. ./build_docker/./src/Common/AsynchronousMetrics.cpp:0: DB::AsynchronousMetrics::run() @ 0x000000001b05c4da 9. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::AsynchronousMetrics::start()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001b05e807 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 12. asan_thread_start(void*) @ 0x000000000aa43059 13. ? @ 0x00007f35aab92ac3 14. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:07:42.250407 [ 20353 ] {c0731e8c-d795-41b0-a332-c2edd6918048} 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.10505.altinitytest (altinity build)) (from [::1]:46266) (comment: 02789_filesystem_cache_alignment.sh) (in query: SELECT count() FROM ( SELECT * FROM (SELECT * FROM ( SELECT cache_path, file_size, tupleElement(file_segment_range, 2) - tupleElement(file_segment_range, 1) + 1 as file_segment_size, formatReadableSize(file_size) as formatted_file_size, formatReadableSize(file_segment_size) as formatted_file_segment_size, tupleElement(file_segment_range, 2) as end_offset FROM ( SELECT arrayJoin(cache_paths) AS cache_path, local_path, remote_path, size as file_size FROM system.remote_data_paths WHERE endsWith(local_path, '.bin') ) AS data_paths INNER JOIN system.filesystem_cache_log AS cache_log ON data_paths.remote_path = cache_log.source_file_path WHERE query_id = '20490' )) AS cache_log INNER JOIN system.filesystem_cache AS cache ON cache_log.cache_path = cache.cache_path ) WHERE file_segment_range_begin - file_segment_range_end + 1 < file_size AND file_segment_range_end + 1 != file_size AND formatReadableSize(downloaded_size) in ('20.00 MiB', '40.00 MiB');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af819ed 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80746 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d34b5ca 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000002d3486e4 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000002d34827b 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002d36bcf7 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 12. asan_thread_start(void*) @ 0x000000000aa43059 13. ? @ 0x00007f35aab92ac3 14. ? @ 0x00007f35aac24850 2025.09.09 15:07:42.296344 [ 2814 ] {} test_3.part_header_r1 (badd489f-7d85-4dd7-8882-42d31f43e543): 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. ./contrib/llvm-project/libcxx/include/string:1499: _ZN12Coordination9ExceptionC2IRA16_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x000000002e65bfe6 3. ./src/Common/ZooKeeper/IKeeper.h:0: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x000000002e6c2259 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1383: Coordination::ZooKeeper::get(String const&, std::function, std::shared_ptr>) @ 0x000000002e6c4432 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002e5f2b99 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:610: zkutil::ZooKeeper::getImpl(String const&, String&, Coordination::Stat*, std::shared_ptr>) @ 0x000000002e5f1db5 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:701: zkutil::ZooKeeper::tryGetWatch(String const&, String&, Coordination::Stat*, std::function, Coordination::Error*) @ 0x000000002e5f3a1e 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002e5f34d2 9. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:638: zkutil::ZooKeeper::get(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000002e5f320b 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::ReplicatedMergeTreeQueue::pullLogsToQueue(std::shared_ptr, std::function, DB::ReplicatedMergeTreeQueue::PullLogsReason) @ 0x000000002ca78b7b 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002baf68ec 12. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 14. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:07:42.309309 [ 20353 ] {c0731e8c-d795-41b0-a332-c2edd6918048} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=8, jobs=8). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af819ed 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80746 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d34b5ca 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000002d3486e4 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000002d34827b 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002d36bcf7 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 12. asan_thread_start(void*) @ 0x000000000aa43059 13. ? @ 0x00007f35aab92ac3 14. ? @ 0x00007f35aac24850 2025.09.09 15:07:42.418606 [ 2874 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:07:42.786038 [ 2903 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:07:42.789249 [ 2903 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:07:42.789763 [ 2884 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:07:43.068326 [ 20350 ] {14112603-0db3-4ff5-9a35-55155463d18b} executeQuery: Code: 630. DB::Exception: Cannot drop or rename database_for_dict.table_for_dict (cabf9a66-80e2-4148-8335-3c53187f5a8a), because some tables depend on it: ordinary_db.dict1. (HAVE_DEPENDENT_OBJECTS) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:52392) (comment: 01542_dictionary_load_exception_race.sh) (in query: DROP DATABASE IF EXISTS database_for_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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception, std::__wrap_iter, char>>(int, FormatStringHelperImpl::type, std::type_identity, std::__wrap_iter, char>>::type>, DB::StorageID const&, fmt::v9::join_view, std::__wrap_iter, char>&&) @ 0x00000000286dbc7a 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:1536: DB::DatabaseCatalog::checkTableCanBeRemovedOrRenamedUnlocked(DB::StorageID const&, bool, bool, bool) const @ 0x00000000286cc3da 5. ./contrib/llvm-project/libcxx/include/__mutex_base:100: DB::DatabaseCatalog::checkTableCanBeRemovedOrRenamed(DB::StorageID const&, bool, bool, bool) const @ 0x00000000286cc97f 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x00000000291f0b89 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:454: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x00000000291f510c 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:361: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000291edc97 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x00000000291ebf11 10. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x00000000291eb7ed 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b382fc 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 14. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 19. asan_thread_start(void*) @ 0x000000000aa43059 20. ? @ 0x00007f35aab92ac3 21. ? @ 0x00007f35aac24850 2025.09.09 15:07:43.083068 [ 20350 ] {14112603-0db3-4ff5-9a35-55155463d18b} TCPHandler: Code: 630. DB::Exception: Cannot drop or rename database_for_dict.table_for_dict (cabf9a66-80e2-4148-8335-3c53187f5a8a), because some tables depend on it: ordinary_db.dict1. (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception, std::__wrap_iter, char>>(int, FormatStringHelperImpl::type, std::type_identity, std::__wrap_iter, char>>::type>, DB::StorageID const&, fmt::v9::join_view, std::__wrap_iter, char>&&) @ 0x00000000286dbc7a 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:1536: DB::DatabaseCatalog::checkTableCanBeRemovedOrRenamedUnlocked(DB::StorageID const&, bool, bool, bool) const @ 0x00000000286cc3da 5. ./contrib/llvm-project/libcxx/include/__mutex_base:100: DB::DatabaseCatalog::checkTableCanBeRemovedOrRenamed(DB::StorageID const&, bool, bool, bool) const @ 0x00000000286cc97f 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x00000000291f0b89 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:454: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x00000000291f510c 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:361: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000291edc97 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x00000000291ebf11 10. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x00000000291eb7ed 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b382fc 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 14. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 19. asan_thread_start(void*) @ 0x000000000aa43059 20. ? @ 0x00007f35aab92ac3 21. ? @ 0x00007f35aac24850 2025.09.09 15:07:43.427792 [ 2988 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:07:43.789089 [ 2982 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:07:43.793213 [ 2995 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:07:43.792569 [ 2975 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:07:43.933212 [ 20345 ] {eae7b180-3322-4f97-9807-25b89225cf23} executeQuery: Code: 42. DB::Exception: Number of arguments for function arrayPopBack doesn't match: passed 2, should be 1: In scope SELECT arrayPopBack(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT arrayPopBack(NULL, NULL);) 2025.09.09 15:07:43.939100 [ 20345 ] {eae7b180-3322-4f97-9807-25b89225cf23} TCPHandler: Code: 42. DB::Exception: Number of arguments for function arrayPopBack doesn't match: passed 2, should be 1: In scope SELECT arrayPopBack(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:07:44.061812 [ 20345 ] {6d80fd33-b83f-415a-9403-3e0d9a9c19ad} executeQuery: Code: 42. DB::Exception: Number of arguments for function arrayPopFront doesn't match: passed 2, should be 1: In scope SELECT arrayPopFront(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT arrayPopFront(NULL, NULL);) 2025.09.09 15:07:44.073990 [ 20345 ] {6d80fd33-b83f-415a-9403-3e0d9a9c19ad} TCPHandler: Code: 42. DB::Exception: Number of arguments for function arrayPopFront doesn't match: passed 2, should be 1: In scope SELECT arrayPopFront(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:07:44.257201 [ 3464 ] {} test_0473czib.mt (37fd3cf2-879f-4934-ac8d-662471988a31): dropAllData: got exception removing parts from disk, removing successfully removed parts from memory. 2025.09.09 15:07:44.259566 [ 3464 ] {} DatabaseCatalog: Cannot drop table test_0473czib.mt (37fd3cf2-879f-4934-ac8d-662471988a31). 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af80b71 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80746 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000263a174e 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002c47c445 8. ./contrib/llvm-project/libcxx/include/vector:547: DB::MergeTreeData::clearPartsFromFilesystem(std::vector, std::allocator>> const&, bool, std::unordered_set, std::equal_to, std::allocator>*) @ 0x000000002c47a78e 9. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::dropAllData() @ 0x000000002c4862d9 10. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::dropTableFinally(DB::DatabaseCatalog::TableMarkedAsDropped const&) @ 0x00000000286c7c77 11. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: void std::__function::__policy_invoker::__call_impl, std::allocator>>)::$_0, void ()>>(std::__function::__policy_storage const*) @ 0x00000000286d9744 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000263a3ea5 13. ./contrib/llvm-project/libcxx/include/future:0: std::packaged_task::operator()() @ 0x000000001bba33ac 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7eaf0 15. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001af8a79f 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 18. asan_thread_start(void*) @ 0x000000000aa43059 19. ? @ 0x00007f35aab92ac3 20. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:07:44.430051 [ 3046 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:07:44.791296 [ 3067 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:07:44.796579 [ 3096 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:07:44.796652 [ 3018 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:07:44.801997 [ 20345 ] {348c87be-82fb-48e0-9881-6ccab70799b1} executeQuery: Code: 43. DB::Exception: First argument for function arrayReduce must be constant string: name of aggregate function.: In scope SELECT arrayReduce(NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT arrayReduce(NULL, NULL);) 2025.09.09 15:07:44.812763 [ 20345 ] {348c87be-82fb-48e0-9881-6ccab70799b1} TCPHandler: Code: 43. DB::Exception: First argument for function arrayReduce must be constant string: name of aggregate function.: In scope SELECT arrayReduce(NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.09.09 15:07:45.218303 [ 20345 ] {faa733ef-260f-4927-977b-72f328fcff86} executeQuery: Code: 42. DB::Exception: Number of arguments for function arrayReverse doesn't match: passed 2, should be 1: In scope SELECT arrayReverse(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT arrayReverse(NULL, NULL);) 2025.09.09 15:07:45.235219 [ 20345 ] {faa733ef-260f-4927-977b-72f328fcff86} TCPHandler: Code: 42. DB::Exception: Number of arguments for function arrayReverse doesn't match: passed 2, should be 1: In scope SELECT arrayReverse(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:07:45.435810 [ 3119 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:07:45.786764 [ 20351 ] {64c09910-6c63-4d10-94e1-1c8cd22c60dc} executeQuery: Code: 630. DB::Exception: Cannot drop or rename database_for_dict.table_for_dict (cabf9a66-80e2-4148-8335-3c53187f5a8a), because some tables depend on it: ordinary_db.dict1. (HAVE_DEPENDENT_OBJECTS) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:52414) (comment: 01542_dictionary_load_exception_race.sh) (in query: DROP DATABASE IF EXISTS database_for_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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception, std::__wrap_iter, char>>(int, FormatStringHelperImpl::type, std::type_identity, std::__wrap_iter, char>>::type>, DB::StorageID const&, fmt::v9::join_view, std::__wrap_iter, char>&&) @ 0x00000000286dbc7a 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:1536: DB::DatabaseCatalog::checkTableCanBeRemovedOrRenamedUnlocked(DB::StorageID const&, bool, bool, bool) const @ 0x00000000286cc3da 5. ./contrib/llvm-project/libcxx/include/__mutex_base:100: DB::DatabaseCatalog::checkTableCanBeRemovedOrRenamed(DB::StorageID const&, bool, bool, bool) const @ 0x00000000286cc97f 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x00000000291f0b89 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:454: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x00000000291f510c 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:361: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000291edc97 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x00000000291ebf11 10. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x00000000291eb7ed 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b382fc 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 14. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 19. asan_thread_start(void*) @ 0x000000000aa43059 20. ? @ 0x00007f35aab92ac3 21. ? @ 0x00007f35aac24850 2025.09.09 15:07:45.795889 [ 20351 ] {64c09910-6c63-4d10-94e1-1c8cd22c60dc} TCPHandler: Code: 630. DB::Exception: Cannot drop or rename database_for_dict.table_for_dict (cabf9a66-80e2-4148-8335-3c53187f5a8a), because some tables depend on it: ordinary_db.dict1. (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception, std::__wrap_iter, char>>(int, FormatStringHelperImpl::type, std::type_identity, std::__wrap_iter, char>>::type>, DB::StorageID const&, fmt::v9::join_view, std::__wrap_iter, char>&&) @ 0x00000000286dbc7a 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:1536: DB::DatabaseCatalog::checkTableCanBeRemovedOrRenamedUnlocked(DB::StorageID const&, bool, bool, bool) const @ 0x00000000286cc3da 5. ./contrib/llvm-project/libcxx/include/__mutex_base:100: DB::DatabaseCatalog::checkTableCanBeRemovedOrRenamed(DB::StorageID const&, bool, bool, bool) const @ 0x00000000286cc97f 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x00000000291f0b89 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:454: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x00000000291f510c 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:361: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000291edc97 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x00000000291ebf11 10. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x00000000291eb7ed 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b382fc 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 14. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 19. asan_thread_start(void*) @ 0x000000000aa43059 20. ? @ 0x00007f35aab92ac3 21. ? @ 0x00007f35aac24850 2025.09.09 15:07:45.796510 [ 3141 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:07:45.799225 [ 3149 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:07:45.799969 [ 3172 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:07:46.090105 [ 20350 ] {34b38abd-ad2c-47d7-8126-ec93148f4bc4} executeQuery: Code: 344. DB::Exception: IN with subquery is not supported with parallel replicas. (SUPPORT_IS_DISABLED) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:52408) (comment: 02949_parallel_replicas_in_subquery.sql) (in query: SELECT * FROM merge_tree_in_subqueries WHERE id IN (SELECT * FROM system.numbers LIMIT 0) SETTINGS enable_parallel_replicas=2, parallel_replicas_allow_in_with_subquery=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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aac868e 4. ./build_docker/./src/Planner/Planner.cpp:1428: DB::Planner::buildPlanForQueryNode() @ 0x0000000029436aad 5. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x00000000294261fb 6. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000029421552 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1182: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3737e 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 15. asan_thread_start(void*) @ 0x000000000aa43059 16. ? @ 0x00007f35aab92ac3 17. ? @ 0x00007f35aac24850 2025.09.09 15:07:46.094587 [ 20350 ] {34b38abd-ad2c-47d7-8126-ec93148f4bc4} TCPHandler: Code: 344. DB::Exception: IN with subquery is not supported with parallel replicas. (SUPPORT_IS_DISABLED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aac868e 4. ./build_docker/./src/Planner/Planner.cpp:1428: DB::Planner::buildPlanForQueryNode() @ 0x0000000029436aad 5. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x00000000294261fb 6. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000029421552 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1182: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3737e 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 15. asan_thread_start(void*) @ 0x000000000aa43059 16. ? @ 0x00007f35aab92ac3 17. ? @ 0x00007f35aac24850 2025.09.09 15:07:46.438720 [ 3202 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:07:46.640420 [ 20351 ] {6291b4a7-9bb5-456e-a326-639fb18be253} executeQuery: Code: 82. DB::Exception: Database database_for_dict already exists. (DATABASE_ALREADY_EXISTS) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:52422) (comment: 01542_dictionary_load_exception_race.sh) (in query: CREATE DATABASE database_for_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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x000000000aafc574 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:146: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002918fd00 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000291c33d8 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b382fc 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 9. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 13. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 14. asan_thread_start(void*) @ 0x000000000aa43059 15. ? @ 0x00007f35aab92ac3 16. ? @ 0x00007f35aac24850 2025.09.09 15:07:46.653273 [ 20351 ] {6291b4a7-9bb5-456e-a326-639fb18be253} TCPHandler: Code: 82. DB::Exception: Database database_for_dict already exists. (DATABASE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x000000000aafc574 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:146: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002918fd00 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000291c33d8 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b382fc 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 9. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 13. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 14. asan_thread_start(void*) @ 0x000000000aa43059 15. ? @ 0x00007f35aab92ac3 16. ? @ 0x00007f35aac24850 2025.09.09 15:07:46.799810 [ 2767 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:07:46.803884 [ 2736 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:07:46.808944 [ 2767 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:07:47.275923 [ 20350 ] {4c94f6ad-83be-4bfe-893c-478396182d81} executeQuery: Code: 344. DB::Exception: IN with subquery is not supported with parallel replicas. (SUPPORT_IS_DISABLED) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:52408) (comment: 02949_parallel_replicas_in_subquery.sql) (in query: SELECT * FROM merge_tree_in_subqueries WHERE id IN (SELECT * FROM system.numbers LIMIT 2, 3) ORDER BY id SETTINGS enable_parallel_replicas=2, parallel_replicas_allow_in_with_subquery=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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aac868e 4. ./build_docker/./src/Planner/Planner.cpp:1428: DB::Planner::buildPlanForQueryNode() @ 0x0000000029436aad 5. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x00000000294261fb 6. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000029421552 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1182: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3737e 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 15. asan_thread_start(void*) @ 0x000000000aa43059 16. ? @ 0x00007f35aab92ac3 17. ? @ 0x00007f35aac24850 2025.09.09 15:07:47.277742 [ 20350 ] {4c94f6ad-83be-4bfe-893c-478396182d81} TCPHandler: Code: 344. DB::Exception: IN with subquery is not supported with parallel replicas. (SUPPORT_IS_DISABLED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aac868e 4. ./build_docker/./src/Planner/Planner.cpp:1428: DB::Planner::buildPlanForQueryNode() @ 0x0000000029436aad 5. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x00000000294261fb 6. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000029421552 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1182: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3737e 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 15. asan_thread_start(void*) @ 0x000000000aa43059 16. ? @ 0x00007f35aab92ac3 17. ? @ 0x00007f35aac24850 2025.09.09 15:07:47.385691 [ 20345 ] {0700e8dc-21ba-4182-b65c-d0eefa98f36e} executeQuery: Code: 43. DB::Exception: Illegal type Nullable(Nothing) of argument of function arrayWithConstant, expected Integer: In scope SELECT arrayWithConstant(NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT arrayWithConstant(NULL, NULL);) 2025.09.09 15:07:47.390497 [ 20345 ] {0700e8dc-21ba-4182-b65c-d0eefa98f36e} TCPHandler: Code: 43. DB::Exception: Illegal type Nullable(Nothing) of argument of function arrayWithConstant, expected Integer: In scope SELECT arrayWithConstant(NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.09.09 15:07:47.392020 [ 20351 ] {989cadd3-dbf7-4981-9a00-42b900fd5114} executeQuery: Code: 630. DB::Exception: Cannot drop or rename database_for_dict.table_for_dict (cabf9a66-80e2-4148-8335-3c53187f5a8a), because some tables depend on it: ordinary_db.dict1. (HAVE_DEPENDENT_OBJECTS) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:52428) (comment: 01542_dictionary_load_exception_race.sh) (in query: DROP TABLE IF EXISTS database_for_dict.table_for_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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception, std::__wrap_iter, char>>(int, FormatStringHelperImpl::type, std::type_identity, std::__wrap_iter, char>>::type>, DB::StorageID const&, fmt::v9::join_view, std::__wrap_iter, char>&&) @ 0x00000000286dbc7a 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:1523: DB::DatabaseCatalog::checkTableCanBeRemovedOrRenamedUnlocked(DB::StorageID const&, bool, bool, bool) const @ 0x00000000286cc315 5. ./contrib/llvm-project/libcxx/include/__mutex_base:100: DB::DatabaseCatalog::checkTableCanBeRemovedOrRenamed(DB::StorageID const&, bool, bool, bool) const @ 0x00000000286cc97f 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x00000000291f0b89 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x00000000291ed665 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x00000000291ebd68 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x00000000291eb7ed 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b382fc 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 13. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 18. asan_thread_start(void*) @ 0x000000000aa43059 19. ? @ 0x00007f35aab92ac3 20. ? @ 0x00007f35aac24850 2025.09.09 15:07:47.401053 [ 20351 ] {989cadd3-dbf7-4981-9a00-42b900fd5114} TCPHandler: Code: 630. DB::Exception: Cannot drop or rename database_for_dict.table_for_dict (cabf9a66-80e2-4148-8335-3c53187f5a8a), because some tables depend on it: ordinary_db.dict1. (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception, std::__wrap_iter, char>>(int, FormatStringHelperImpl::type, std::type_identity, std::__wrap_iter, char>>::type>, DB::StorageID const&, fmt::v9::join_view, std::__wrap_iter, char>&&) @ 0x00000000286dbc7a 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:1523: DB::DatabaseCatalog::checkTableCanBeRemovedOrRenamedUnlocked(DB::StorageID const&, bool, bool, bool) const @ 0x00000000286cc315 5. ./contrib/llvm-project/libcxx/include/__mutex_base:100: DB::DatabaseCatalog::checkTableCanBeRemovedOrRenamed(DB::StorageID const&, bool, bool, bool) const @ 0x00000000286cc97f 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x00000000291f0b89 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x00000000291ed665 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x00000000291ebd68 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x00000000291eb7ed 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b382fc 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 13. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 18. asan_thread_start(void*) @ 0x000000000aa43059 19. ? @ 0x00007f35aab92ac3 20. ? @ 0x00007f35aac24850 2025.09.09 15:07:47.441787 [ 2800 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:07:47.802122 [ 2786 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:07:47.808726 [ 2734 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:07:47.815051 [ 2799 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:07:47.848635 [ 20345 ] {dff65e2f-7711-49d4-a0fc-9fc818c7ed16} executeQuery: Code: 43. DB::Exception: Illegal type Nullable(Nothing) of argument for aggregate function with Array suffix. Must be array. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT array_concat_agg(NULL, NULL);) 2025.09.09 15:07:47.855654 [ 20345 ] {dff65e2f-7711-49d4-a0fc-9fc818c7ed16} TCPHandler: Code: 43. DB::Exception: Illegal type Nullable(Nothing) of argument for aggregate function with Array suffix. Must be array. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.09.09 15:07:47.934074 [ 20345 ] {3dd815c1-b621-4977-bd32-61b98e156196} executeQuery: Code: 42. DB::Exception: Number of arguments for function ascii doesn't match: passed 2, should be 1: In scope SELECT ascii(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT ascii(NULL, NULL);) 2025.09.09 15:07:47.940209 [ 20345 ] {3dd815c1-b621-4977-bd32-61b98e156196} TCPHandler: Code: 42. DB::Exception: Number of arguments for function ascii doesn't match: passed 2, should be 1: In scope SELECT ascii(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:07:48.013570 [ 20345 ] {b78b0717-9a2b-4e0d-8dfc-b59c7443cddb} executeQuery: Code: 42. DB::Exception: Number of arguments for function asin doesn't match: passed 2, should be 1: In scope SELECT asin(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT asin(NULL, NULL);) 2025.09.09 15:07:48.018891 [ 20345 ] {b78b0717-9a2b-4e0d-8dfc-b59c7443cddb} TCPHandler: Code: 42. DB::Exception: Number of arguments for function asin doesn't match: passed 2, should be 1: In scope SELECT asin(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:07:48.091519 [ 20345 ] {0a1807d7-d7d4-4f5b-a4fc-6925c0835a02} executeQuery: Code: 42. DB::Exception: Number of arguments for function asinh doesn't match: passed 2, should be 1: In scope SELECT asinh(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT asinh(NULL, NULL);) 2025.09.09 15:07:48.098358 [ 20345 ] {0a1807d7-d7d4-4f5b-a4fc-6925c0835a02} TCPHandler: Code: 42. DB::Exception: Number of arguments for function asinh doesn't match: passed 2, should be 1: In scope SELECT asinh(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:07:48.149917 [ 20345 ] {b0be0d58-e5f4-4a38-be31-eed8f17c3d05} executeQuery: Code: 42. DB::Exception: Number of arguments for function assumeNotNull doesn't match: passed 2, should be 1: In scope SELECT assumeNotNull(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT assumeNotNull(NULL, NULL);) 2025.09.09 15:07:48.153495 [ 20345 ] {b0be0d58-e5f4-4a38-be31-eed8f17c3d05} TCPHandler: Code: 42. DB::Exception: Number of arguments for function assumeNotNull doesn't match: passed 2, should be 1: In scope SELECT assumeNotNull(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:07:48.205648 [ 20345 ] {7d35317b-eaa1-4706-ae6d-854856be8f5c} executeQuery: Code: 42. DB::Exception: Number of arguments for function atan doesn't match: passed 2, should be 1: In scope SELECT atan(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT atan(NULL, NULL);) 2025.09.09 15:07:48.208842 [ 20345 ] {7d35317b-eaa1-4706-ae6d-854856be8f5c} TCPHandler: Code: 42. DB::Exception: Number of arguments for function atan doesn't match: passed 2, should be 1: In scope SELECT atan(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:07:48.213350 [ 20351 ] {12f97392-8f8b-4a54-a32f-81aec35f3d55} executeQuery: Code: 57. DB::Exception: Table database_for_dict.table_for_dict already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:43990) (comment: 01542_dictionary_load_exception_race.sh) (in query: CREATE TABLE database_for_dict.table_for_dict (`key_column` UInt64, `second_column` UInt64, `third_column` String) ENGINE = MergeTree ORDER BY key_column SETTINGS index_granularity = 60578, min_bytes_for_wide_part = 592817471, ratio_of_defaults_for_sparse_serialization = 0.3581370711326599, replace_long_file_name_to_hash = false, max_file_name_length = 60, min_bytes_for_full_part_storage = 510714276, compact_parts_max_bytes_to_buffer = 480424706, compact_parts_max_granules_to_buffer = 127, compact_parts_merge_max_bytes_to_prefetch_part = 31072451, merge_max_block_size = 24278, old_parts_lifetime = 480., prefer_fetch_merged_part_size_threshold = 10737418240, vertical_merge_algorithm_min_rows_to_activate = 1000000, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 10737418240, index_granularity_bytes = 3546291, concurrent_part_removal_threshold = 14, allow_vertical_merges_from_compact_to_wide_parts = true, cache_populated_by_fetch = true, marks_compress_block_size = 74214, primary_key_compress_block_size = 17858), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa91e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1558: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291bc5ff 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291ac835 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000291c3415 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b382fc 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 15. asan_thread_start(void*) @ 0x000000000aa43059 16. ? @ 0x00007f35aab92ac3 17. ? @ 0x00007f35aac24850 2025.09.09 15:07:48.229379 [ 20351 ] {12f97392-8f8b-4a54-a32f-81aec35f3d55} TCPHandler: Code: 57. DB::Exception: Table database_for_dict.table_for_dict already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa91e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1558: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291bc5ff 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291ac835 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000291c3415 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b382fc 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 15. asan_thread_start(void*) @ 0x000000000aa43059 16. ? @ 0x00007f35aab92ac3 17. ? @ 0x00007f35aac24850 2025.09.09 15:07:48.433421 [ 20345 ] {01655388-0a5e-4565-b9bf-cdfdb0c85b1a} executeQuery: Code: 42. DB::Exception: Number of arguments for function atanh doesn't match: passed 2, should be 1: In scope SELECT atanh(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT atanh(NULL, NULL);) 2025.09.09 15:07:48.436689 [ 20345 ] {01655388-0a5e-4565-b9bf-cdfdb0c85b1a} TCPHandler: Code: 42. DB::Exception: Number of arguments for function atanh doesn't match: passed 2, should be 1: In scope SELECT atanh(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:07:48.437815 [ 20350 ] {2006cd20-c352-4c17-ab59-800fea935f38} executeQuery: Code: 344. DB::Exception: IN with subquery is not supported with parallel replicas. (SUPPORT_IS_DISABLED) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:52408) (comment: 02949_parallel_replicas_in_subquery.sql) (in query: SELECT * FROM merge_tree_in_subqueries WHERE id IN (SELECT 1) ORDER BY id SETTINGS enable_parallel_replicas=2, parallel_replicas_allow_in_with_subquery=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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aac868e 4. ./build_docker/./src/Planner/Planner.cpp:1428: DB::Planner::buildPlanForQueryNode() @ 0x0000000029436aad 5. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x00000000294261fb 6. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000029421552 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1182: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3737e 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 15. asan_thread_start(void*) @ 0x000000000aa43059 16. ? @ 0x00007f35aab92ac3 17. ? @ 0x00007f35aac24850 2025.09.09 15:07:48.441359 [ 20350 ] {2006cd20-c352-4c17-ab59-800fea935f38} TCPHandler: Code: 344. DB::Exception: IN with subquery is not supported with parallel replicas. (SUPPORT_IS_DISABLED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aac868e 4. ./build_docker/./src/Planner/Planner.cpp:1428: DB::Planner::buildPlanForQueryNode() @ 0x0000000029436aad 5. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x00000000294261fb 6. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000029421552 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1182: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3737e 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 15. asan_thread_start(void*) @ 0x000000000aa43059 16. ? @ 0x00007f35aab92ac3 17. ? @ 0x00007f35aac24850 2025.09.09 15:07:48.444738 [ 2899 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:07:48.804883 [ 2941 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:07:48.811678 [ 2913 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:07:48.818157 [ 2946 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:07:49.104874 [ 20345 ] {6f00109b-b5e2-467e-aab1-d0900b753d02} executeQuery: Code: 42. DB::Exception: Number of arguments for function base58Decode doesn't match: passed 2, should be 1: In scope SELECT base58Decode(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT base58Decode(NULL, NULL);) 2025.09.09 15:07:49.111074 [ 20345 ] {6f00109b-b5e2-467e-aab1-d0900b753d02} TCPHandler: Code: 42. DB::Exception: Number of arguments for function base58Decode doesn't match: passed 2, should be 1: In scope SELECT base58Decode(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:07:49.221994 [ 20345 ] {9aa05963-5b14-4658-8537-21e3a5805e5f} executeQuery: Code: 42. DB::Exception: Number of arguments for function base58Encode doesn't match: passed 2, should be 1: In scope SELECT base58Encode(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT base58Encode(NULL, NULL);) 2025.09.09 15:07:49.229239 [ 20345 ] {9aa05963-5b14-4658-8537-21e3a5805e5f} TCPHandler: Code: 42. DB::Exception: Number of arguments for function base58Encode doesn't match: passed 2, should be 1: In scope SELECT base58Encode(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:07:49.346142 [ 20345 ] {8567d8ba-ff94-4619-a68a-67feaf91c2f8} executeQuery: Code: 42. DB::Exception: Number of arguments for function base64Decode doesn't match: passed 2, should be 1: In scope SELECT base64Decode(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT base64Decode(NULL, NULL);) 2025.09.09 15:07:49.360338 [ 20345 ] {8567d8ba-ff94-4619-a68a-67feaf91c2f8} TCPHandler: Code: 42. DB::Exception: Number of arguments for function base64Decode doesn't match: passed 2, should be 1: In scope SELECT base64Decode(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:07:49.446590 [ 2920 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:07:49.450977 [ 20345 ] {f7df62e0-b969-400b-8fd3-060d6e754e0b} executeQuery: Code: 42. DB::Exception: Number of arguments for function base64Encode doesn't match: passed 2, should be 1: In scope SELECT base64Encode(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT base64Encode(NULL, NULL);) 2025.09.09 15:07:49.455066 [ 20345 ] {f7df62e0-b969-400b-8fd3-060d6e754e0b} TCPHandler: Code: 42. DB::Exception: Number of arguments for function base64Encode doesn't match: passed 2, should be 1: In scope SELECT base64Encode(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:07:49.489141 [ 20162 ] {} test_0473czib.mt (37fd3cf2-879f-4934-ac8d-662471988a31): dropAllData: got exception removing parts from disk, removing successfully removed parts from memory. 2025.09.09 15:07:49.491052 [ 20162 ] {} DatabaseCatalog: Cannot drop table test_0473czib.mt (37fd3cf2-879f-4934-ac8d-662471988a31). Will retry later.: 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af80b71 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80746 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000263a174e 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002c47c445 8. ./contrib/llvm-project/libcxx/include/vector:547: DB::MergeTreeData::clearPartsFromFilesystem(std::vector, std::allocator>> const&, bool, std::unordered_set, std::equal_to, std::allocator>*) @ 0x000000002c47a78e 9. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::dropAllData() @ 0x000000002c4862d9 10. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::dropTableFinally(DB::DatabaseCatalog::TableMarkedAsDropped const&) @ 0x00000000286c7c77 11. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: void std::__function::__policy_invoker::__call_impl, std::allocator>>)::$_0, void ()>>(std::__function::__policy_storage const*) @ 0x00000000286d9744 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000263a3ea5 13. ./contrib/llvm-project/libcxx/include/future:0: std::packaged_task::operator()() @ 0x000000001bba33ac 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7eaf0 15. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001af8a79f 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 18. asan_thread_start(void*) @ 0x000000000aa43059 19. ? @ 0x00007f35aab92ac3 20. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:07:49.497787 [ 20345 ] {6e618527-0b99-4ee7-8529-47a25f890c7b} executeQuery: Code: 42. DB::Exception: Number of arguments for function base64URLDecode doesn't match: passed 2, should be 1: In scope SELECT base64URLDecode(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT base64URLDecode(NULL, NULL);) 2025.09.09 15:07:49.509929 [ 20345 ] {6e618527-0b99-4ee7-8529-47a25f890c7b} TCPHandler: Code: 42. DB::Exception: Number of arguments for function base64URLDecode doesn't match: passed 2, should be 1: In scope SELECT base64URLDecode(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:07:49.558702 [ 20345 ] {0eb4a054-eb48-494d-b22b-348972c95aac} executeQuery: Code: 42. DB::Exception: Number of arguments for function base64URLEncode doesn't match: passed 2, should be 1: In scope SELECT base64URLEncode(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT base64URLEncode(NULL, NULL);) 2025.09.09 15:07:49.562336 [ 20345 ] {0eb4a054-eb48-494d-b22b-348972c95aac} TCPHandler: Code: 42. DB::Exception: Number of arguments for function base64URLEncode doesn't match: passed 2, should be 1: In scope SELECT base64URLEncode(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:07:49.685952 [ 20351 ] {de569dea-1076-40ef-825b-a3b7cb49ef6e} executeQuery: Code: 62. DB::Exception: Cannot TRUNCATE dictionary. (SYNTAX_ERROR) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:44014) (comment: 01542_dictionary_load_exception_race.sh) (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aac868e 4. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:262: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x00000000291f1adc 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>>>&) @ 0x00000000291f510c 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:361: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000291edc97 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x00000000291ebf11 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x00000000291eb7ed 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b382fc 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 15:07:49.687125 [ 20345 ] {b3c5fe1f-9f27-4f86-b35a-9ec5d617283e} executeQuery: Code: 42. DB::Exception: Number of arguments for function basename doesn't match: passed 2, should be 1: In scope SELECT basename(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT basename(NULL, NULL);) 2025.09.09 15:07:49.697899 [ 20351 ] {de569dea-1076-40ef-825b-a3b7cb49ef6e} 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aac868e 4. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:262: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x00000000291f1adc 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>>>&) @ 0x00000000291f510c 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:361: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000291edc97 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x00000000291ebf11 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x00000000291eb7ed 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b382fc 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 15:07:49.699124 [ 20345 ] {b3c5fe1f-9f27-4f86-b35a-9ec5d617283e} TCPHandler: Code: 42. DB::Exception: Number of arguments for function basename doesn't match: passed 2, should be 1: In scope SELECT basename(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:07:49.764249 [ 20345 ] {5aaea624-577d-48f7-aff9-b496733631e5} executeQuery: Code: 42. DB::Exception: Number of arguments for function bin doesn't match: passed 2, should be 1: In scope SELECT bin(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT bin(NULL, NULL);) 2025.09.09 15:07:49.771347 [ 20345 ] {5aaea624-577d-48f7-aff9-b496733631e5} TCPHandler: Code: 42. DB::Exception: Number of arguments for function bin doesn't match: passed 2, should be 1: In scope SELECT bin(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:07:49.807896 [ 2984 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:07:49.814905 [ 2991 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:07:49.821627 [ 2994 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:07:50.026499 [ 20345 ] {ec4838c0-1ee4-447e-a83b-c17688d0f733} executeQuery: Code: 42. DB::Exception: Number of arguments for function bitCount doesn't match: passed 2, should be 1: In scope SELECT bitCount(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT bitCount(NULL, NULL);) 2025.09.09 15:07:50.032711 [ 20345 ] {ec4838c0-1ee4-447e-a83b-c17688d0f733} TCPHandler: Code: 42. DB::Exception: Number of arguments for function bitCount doesn't match: passed 2, should be 1: In scope SELECT bitCount(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:07:50.199007 [ 20345 ] {67b2f609-395d-4221-9193-a1cbdee0813c} executeQuery: Code: 42. DB::Exception: Number of arguments for function bitNot doesn't match: passed 2, should be 1: In scope SELECT bitNot(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT bitNot(NULL, NULL);) 2025.09.09 15:07:50.203405 [ 20345 ] {67b2f609-395d-4221-9193-a1cbdee0813c} TCPHandler: Code: 42. DB::Exception: Number of arguments for function bitNot doesn't match: passed 2, should be 1: In scope SELECT bitNot(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:07:50.422949 [ 20350 ] {fa34593c-2895-499e-b721-7a5a46f19033} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=790, jobs=739). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:52408) (comment: 02949_parallel_replicas_in_subquery.sql) (in query: SELECT id, name FROM merge_tree_in_subqueries WHERE (id, name) IN (3, 'test3') SETTINGS enable_parallel_replicas=2, parallel_replicas_allow_in_with_subquery=1;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af872f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af7b2d1 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af7c3f3 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d36920d 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000002d369e5f 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processOrdinaryQuery() @ 0x000000002d18af7b 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d17644a 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 15. asan_thread_start(void*) @ 0x000000000aa43059 16. ? @ 0x00007f35aab92ac3 17. ? @ 0x00007f35aac24850 2025.09.09 15:07:50.428831 [ 20350 ] {fa34593c-2895-499e-b721-7a5a46f19033} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=790, 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af872f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af7b2d1 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af7c3f3 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d36920d 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000002d369e5f 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processOrdinaryQuery() @ 0x000000002d18af7b 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d17644a 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 15. asan_thread_start(void*) @ 0x000000000aa43059 16. ? @ 0x00007f35aab92ac3 17. ? @ 0x00007f35aac24850 2025.09.09 15:07:50.431319 [ 20345 ] {6f6b2059-ddb8-4d73-90f1-06969014e6cd} executeQuery: Code: 42. DB::Exception: Number of arguments for function bitPositionsToArray doesn't match: passed 2, should be 1: In scope SELECT bitPositionsToArray(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT bitPositionsToArray(NULL, NULL);) 2025.09.09 15:07:50.442217 [ 20345 ] {6f6b2059-ddb8-4d73-90f1-06969014e6cd} TCPHandler: Code: 42. DB::Exception: Number of arguments for function bitPositionsToArray doesn't match: passed 2, should be 1: In scope SELECT bitPositionsToArray(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:07:50.448364 [ 3031 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:07:50.581515 [ 20350 ] {daaeacff-dd9a-4563-8cf6-226959d34aa5} executeQuery: Code: 82. DB::Exception: Database ordinary_db already exists. (DATABASE_ALREADY_EXISTS) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:44024) (comment: 01542_dictionary_load_exception_race.sh) (in query: CREATE DATABASE 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x000000000aafc574 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:146: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002918fd00 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000291c33d8 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b382fc 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 9. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 13. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 14. asan_thread_start(void*) @ 0x000000000aa43059 15. ? @ 0x00007f35aab92ac3 16. ? @ 0x00007f35aac24850 2025.09.09 15:07:50.588008 [ 20350 ] {daaeacff-dd9a-4563-8cf6-226959d34aa5} TCPHandler: Code: 82. DB::Exception: Database ordinary_db already exists. (DATABASE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x000000000aafc574 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:146: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002918fd00 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000291c33d8 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b382fc 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 9. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 13. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 14. asan_thread_start(void*) @ 0x000000000aa43059 15. ? @ 0x00007f35aab92ac3 16. ? @ 0x00007f35aac24850 2025.09.09 15:07:50.810130 [ 3046 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:07:50.817378 [ 3047 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:07:50.824715 [ 3063 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:07:51.163437 [ 20351 ] {f6c99a78-64ea-43c3-a482-831241e4f7cd} executeQuery: Code: 387. DB::Exception: Dictionary ordinary_db.dict1 already exists. (DICTIONARY_ALREADY_EXISTS) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:44056) (comment: 01542_dictionary_load_exception_race.sh) (in query: CREATE DICTIONARY ordinary_db.dict1 (`key_column` UInt64 DEFAULT 0, `second_column` UInt64 DEFAULT 1, `third_column` String DEFAULT 'qqq') PRIMARY KEY key_column SOURCE(CLICKHOUSE(HOST 'localhost' PORT tcpPort() USER 'default' TABLE 'table_for_dict' PASSWORD '[HIDDEN]' DB 'database_for_dict')) LIFETIME(MIN 1 MAX 10) LAYOUT(FLAT()) SETTINGS(max_result_bytes = 1)), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa91e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1555: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291bc592 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291ac835 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000291c3415 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b382fc 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 15. asan_thread_start(void*) @ 0x000000000aa43059 16. ? @ 0x00007f35aab92ac3 17. ? @ 0x00007f35aac24850 2025.09.09 15:07:51.166675 [ 20351 ] {f6c99a78-64ea-43c3-a482-831241e4f7cd} TCPHandler: Code: 387. DB::Exception: Dictionary ordinary_db.dict1 already exists. (DICTIONARY_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa91e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1555: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291bc592 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291ac835 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000291c3415 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b382fc 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 15. asan_thread_start(void*) @ 0x000000000aa43059 16. ? @ 0x00007f35aab92ac3 17. ? @ 0x00007f35aac24850 2025.09.09 15:07:51.385034 [ 20350 ] {6ec211e4-03ba-4933-abaa-167ab622cf3f} executeQuery: Code: 42. DB::Exception: Number of arguments for function multiply doesn't match: passed 1, should be 2: In scope SELECT max(multiply(1)). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:44040) (comment: 01323_bad_arg_in_arithmetic_operations.sql) (in query: SELECT max(multiply(1));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x000000000ccd84e0 4. DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x000000000ccd2a84 5. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000ccd35cf 6. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000ccd3176 7. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000ccd4343 8. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000028399ff0 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000028367bce 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028366290 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2813: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000028391dce 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000028367bce 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028366290 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283b62c9 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002835ae03 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000028359104 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000028357f0d 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002921bdcc 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&) @ 0x000000002941f313 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&) @ 0x0000000029419aef 21. ./contrib/llvm-project/libcxx/include/vector:432: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000029421f5d 22. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000029344c1b 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*) @ 0x0000000029b3703b 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 25. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 26. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 30. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 31. asan_thread_start(void*) @ 0x000000000aa43059 2025.09.09 15:07:51.386601 [ 20350 ] {6ec211e4-03ba-4933-abaa-167ab622cf3f} TCPHandler: Code: 42. DB::Exception: Number of arguments for function multiply doesn't match: passed 1, should be 2: In scope SELECT max(multiply(1)). (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x000000000ccd84e0 4. DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x000000000ccd2a84 5. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000ccd35cf 6. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000ccd3176 7. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000ccd4343 8. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000028399ff0 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000028367bce 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028366290 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2813: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000028391dce 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000028367bce 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028366290 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283b62c9 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002835ae03 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000028359104 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000028357f0d 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002921bdcc 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&) @ 0x000000002941f313 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&) @ 0x0000000029419aef 21. ./contrib/llvm-project/libcxx/include/vector:432: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000029421f5d 22. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000029344c1b 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*) @ 0x0000000029b3703b 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 25. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 26. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 30. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 31. asan_thread_start(void*) @ 0x000000000aa43059 2025.09.09 15:07:51.450448 [ 3114 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:07:51.604046 [ 20350 ] {ed1c0e9f-7ee9-4212-a980-17b7f8df408f} executeQuery: Code: 42. DB::Exception: Number of arguments for function multiply doesn't match: passed 1, should be 2: In scope SELECT min(multiply(2)). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:44040) (comment: 01323_bad_arg_in_arithmetic_operations.sql) (in query: SELECT min(multiply(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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x000000000ccd84e0 4. DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x000000000ccd2a84 5. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000ccd35cf 6. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000ccd3176 7. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000ccd4343 8. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000028399ff0 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000028367bce 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028366290 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2813: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000028391dce 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000028367bce 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028366290 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283b62c9 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002835ae03 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000028359104 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000028357f0d 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002921bdcc 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&) @ 0x000000002941f313 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&) @ 0x0000000029419aef 21. ./contrib/llvm-project/libcxx/include/vector:432: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000029421f5d 22. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000029344c1b 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*) @ 0x0000000029b3703b 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 25. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 26. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 30. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 31. asan_thread_start(void*) @ 0x000000000aa43059 2025.09.09 15:07:51.614206 [ 20350 ] {ed1c0e9f-7ee9-4212-a980-17b7f8df408f} TCPHandler: Code: 42. DB::Exception: Number of arguments for function multiply doesn't match: passed 1, should be 2: In scope SELECT min(multiply(2)). (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x000000000ccd84e0 4. DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x000000000ccd2a84 5. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000ccd35cf 6. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000ccd3176 7. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000ccd4343 8. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000028399ff0 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000028367bce 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028366290 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2813: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000028391dce 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000028367bce 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028366290 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283b62c9 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002835ae03 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000028359104 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000028357f0d 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002921bdcc 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&) @ 0x000000002941f313 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&) @ 0x0000000029419aef 21. ./contrib/llvm-project/libcxx/include/vector:432: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000029421f5d 22. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000029344c1b 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*) @ 0x0000000029b3703b 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 25. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 26. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 30. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 31. asan_thread_start(void*) @ 0x000000000aa43059 2025.09.09 15:07:51.744072 [ 20350 ] {b5920370-9884-4db2-b54b-db4b2b796816} executeQuery: Code: 42. DB::Exception: Number of arguments for function multiply doesn't match: passed 1, should be 2: In scope SELECT sum(multiply(3)). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:44040) (comment: 01323_bad_arg_in_arithmetic_operations.sql) (in query: SELECT sum(multiply(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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x000000000ccd84e0 4. DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x000000000ccd2a84 5. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000ccd35cf 6. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000ccd3176 7. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000ccd4343 8. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000028399ff0 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000028367bce 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028366290 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2813: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000028391dce 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000028367bce 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028366290 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283b62c9 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002835ae03 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000028359104 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000028357f0d 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002921bdcc 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&) @ 0x000000002941f313 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&) @ 0x0000000029419aef 21. ./contrib/llvm-project/libcxx/include/vector:432: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000029421f5d 22. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000029344c1b 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*) @ 0x0000000029b3703b 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 25. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 26. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 30. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 31. asan_thread_start(void*) @ 0x000000000aa43059 2025.09.09 15:07:51.747861 [ 20350 ] {b5920370-9884-4db2-b54b-db4b2b796816} TCPHandler: Code: 42. DB::Exception: Number of arguments for function multiply doesn't match: passed 1, should be 2: In scope SELECT sum(multiply(3)). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x000000000ccd84e0 4. DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x000000000ccd2a84 5. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000ccd35cf 6. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000ccd3176 7. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000ccd4343 8. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000028399ff0 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000028367bce 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028366290 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2813: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000028391dce 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000028367bce 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028366290 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283b62c9 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002835ae03 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000028359104 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000028357f0d 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002921bdcc 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&) @ 0x000000002941f313 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&) @ 0x0000000029419aef 21. ./contrib/llvm-project/libcxx/include/vector:432: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000029421f5d 22. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000029344c1b 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*) @ 0x0000000029b3703b 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 25. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 26. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 30. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 31. asan_thread_start(void*) @ 0x000000000aa43059 2025.09.09 15:07:51.812853 [ 3137 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:07:51.819108 [ 3146 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:07:51.826411 [ 3166 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:07:51.850558 [ 20351 ] {93c09930-ffca-4250-bf27-8eea7921c37d} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:44060) (comment: 01542_dictionary_load_exception_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:51.863385 [ 20350 ] {d5151839-faaf-4f26-80a5-916ddb236a95} executeQuery: Code: 42. DB::Exception: Number of arguments for function plus doesn't match: passed 1, should be 2: In scope SELECT max(plus(1)). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:44040) (comment: 01323_bad_arg_in_arithmetic_operations.sql) (in query: SELECT max(plus(1));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x000000000ccd84e0 4. DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x000000000ccd2a84 5. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000ccd35cf 6. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000ccd3176 7. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000ccd4343 8. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000028399ff0 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000028367bce 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028366290 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2813: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000028391dce 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000028367bce 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028366290 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283b62c9 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002835ae03 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000028359104 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000028357f0d 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002921bdcc 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&) @ 0x000000002941f313 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&) @ 0x0000000029419aef 21. ./contrib/llvm-project/libcxx/include/vector:432: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000029421f5d 22. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000029344c1b 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*) @ 0x0000000029b3703b 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 25. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 26. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 30. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 31. asan_thread_start(void*) @ 0x000000000aa43059 2025.09.09 15:07:51.877412 [ 20351 ] {93c09930-ffca-4250-bf27-8eea7921c37d} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:51.878594 [ 20350 ] {d5151839-faaf-4f26-80a5-916ddb236a95} TCPHandler: Code: 42. DB::Exception: Number of arguments for function plus doesn't match: passed 1, should be 2: In scope SELECT max(plus(1)). (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x000000000ccd84e0 4. DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x000000000ccd2a84 5. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000ccd35cf 6. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000ccd3176 7. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000ccd4343 8. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000028399ff0 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000028367bce 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028366290 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2813: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000028391dce 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000028367bce 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028366290 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283b62c9 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002835ae03 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000028359104 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000028357f0d 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002921bdcc 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&) @ 0x000000002941f313 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&) @ 0x0000000029419aef 21. ./contrib/llvm-project/libcxx/include/vector:432: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000029421f5d 22. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000029344c1b 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*) @ 0x0000000029b3703b 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 25. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 26. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 30. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 31. asan_thread_start(void*) @ 0x000000000aa43059 2025.09.09 15:07:51.893496 [ 20379 ] {175724e7-3ff9-4cd8-abb7-b2f5869cf867} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:44064) (comment: 01542_dictionary_load_exception_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:51.901119 [ 20379 ] {175724e7-3ff9-4cd8-abb7-b2f5869cf867} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:51.961933 [ 20380 ] {5ae3ead5-ce58-4a78-a319-bb169c290809} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:44078) (comment: 01542_dictionary_load_exception_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:51.966756 [ 20380 ] {5ae3ead5-ce58-4a78-a319-bb169c290809} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:52.080561 [ 20350 ] {1953b55e-3ef3-4f26-926e-807597d9ca3d} executeQuery: Code: 42. DB::Exception: Number of arguments for function plus doesn't match: passed 1, should be 2: In scope SELECT min(plus(2)). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:44040) (comment: 01323_bad_arg_in_arithmetic_operations.sql) (in query: SELECT min(plus(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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x000000000ccd84e0 4. DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x000000000ccd2a84 5. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000ccd35cf 6. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000ccd3176 7. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000ccd4343 8. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000028399ff0 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000028367bce 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028366290 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2813: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000028391dce 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000028367bce 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028366290 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283b62c9 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002835ae03 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000028359104 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000028357f0d 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002921bdcc 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&) @ 0x000000002941f313 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&) @ 0x0000000029419aef 21. ./contrib/llvm-project/libcxx/include/vector:432: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000029421f5d 22. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000029344c1b 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*) @ 0x0000000029b3703b 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 25. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 26. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 30. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 31. asan_thread_start(void*) @ 0x000000000aa43059 2025.09.09 15:07:52.084829 [ 20350 ] {1953b55e-3ef3-4f26-926e-807597d9ca3d} TCPHandler: Code: 42. DB::Exception: Number of arguments for function plus doesn't match: passed 1, should be 2: In scope SELECT min(plus(2)). (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x000000000ccd84e0 4. DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x000000000ccd2a84 5. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000ccd35cf 6. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000ccd3176 7. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000ccd4343 8. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000028399ff0 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000028367bce 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028366290 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2813: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000028391dce 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000028367bce 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028366290 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283b62c9 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002835ae03 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000028359104 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000028357f0d 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002921bdcc 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&) @ 0x000000002941f313 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&) @ 0x0000000029419aef 21. ./contrib/llvm-project/libcxx/include/vector:432: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000029421f5d 22. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000029344c1b 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*) @ 0x0000000029b3703b 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 25. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 26. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 30. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 31. asan_thread_start(void*) @ 0x000000000aa43059 2025.09.09 15:07:52.094038 [ 2687 ] {bdbacb36-a53b-405b-86ba-a4cb4ace9cd3} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:44102) (comment: 01542_dictionary_load_exception_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:52.101570 [ 2687 ] {bdbacb36-a53b-405b-86ba-a4cb4ace9cd3} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:52.114518 [ 20884 ] {a50e572d-6fb5-4bca-bf0f-8eb80c6f3cac} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:44106) (comment: 01542_dictionary_load_exception_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:52.120889 [ 20884 ] {a50e572d-6fb5-4bca-bf0f-8eb80c6f3cac} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:52.198365 [ 20350 ] {f7a6f8e5-4688-43f4-a36a-72aa9f7d9d5e} executeQuery: Code: 42. DB::Exception: Number of arguments for function plus doesn't match: passed 1, should be 2: In scope SELECT sum(plus(3)). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:44040) (comment: 01323_bad_arg_in_arithmetic_operations.sql) (in query: SELECT sum(plus(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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x000000000ccd84e0 4. DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x000000000ccd2a84 5. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000ccd35cf 6. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000ccd3176 7. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000ccd4343 8. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000028399ff0 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000028367bce 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028366290 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2813: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000028391dce 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000028367bce 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028366290 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283b62c9 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002835ae03 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000028359104 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000028357f0d 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002921bdcc 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&) @ 0x000000002941f313 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&) @ 0x0000000029419aef 21. ./contrib/llvm-project/libcxx/include/vector:432: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000029421f5d 22. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000029344c1b 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*) @ 0x0000000029b3703b 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 25. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 26. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 30. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 31. asan_thread_start(void*) @ 0x000000000aa43059 2025.09.09 15:07:52.202714 [ 20849 ] {c821c14f-c435-42fc-9518-975de30f6008} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:44148) (comment: 01542_dictionary_load_exception_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:52.203169 [ 3722 ] {46ea6a67-bf9a-4d86-8cc0-fddb5685a212} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:44138) (comment: 01542_dictionary_load_exception_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:52.203853 [ 20350 ] {f7a6f8e5-4688-43f4-a36a-72aa9f7d9d5e} TCPHandler: Code: 42. DB::Exception: Number of arguments for function plus doesn't match: passed 1, should be 2: In scope SELECT sum(plus(3)). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x000000000ccd84e0 4. DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x000000000ccd2a84 5. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000ccd35cf 6. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000ccd3176 7. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000ccd4343 8. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000028399ff0 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000028367bce 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028366290 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2813: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000028391dce 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000028367bce 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028366290 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283b62c9 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002835ae03 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000028359104 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000028357f0d 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002921bdcc 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&) @ 0x000000002941f313 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&) @ 0x0000000029419aef 21. ./contrib/llvm-project/libcxx/include/vector:432: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000029421f5d 22. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000029344c1b 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*) @ 0x0000000029b3703b 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 25. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 26. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 30. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 31. asan_thread_start(void*) @ 0x000000000aa43059 2025.09.09 15:07:52.214166 [ 20849 ] {c821c14f-c435-42fc-9518-975de30f6008} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:52.218373 [ 3722 ] {46ea6a67-bf9a-4d86-8cc0-fddb5685a212} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:52.227200 [ 3612 ] {13a8f27e-24a9-49dc-8f1a-7a636464451b} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:44120) (comment: 01542_dictionary_load_exception_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:52.227568 [ 20881 ] {12bebddb-e95d-4ae5-a05d-1b6bb60979c8} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:44128) (comment: 01542_dictionary_load_exception_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:52.227609 [ 2688 ] {7c778c74-d934-4590-a6bc-fd46c7274d13} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:44152) (comment: 01542_dictionary_load_exception_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:52.228918 [ 19252 ] {5893e4a2-516b-491d-908d-c86b407b64de} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:44144) (comment: 01542_dictionary_load_exception_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:52.229084 [ 3612 ] {13a8f27e-24a9-49dc-8f1a-7a636464451b} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:52.238267 [ 2688 ] {7c778c74-d934-4590-a6bc-fd46c7274d13} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:52.248376 [ 20881 ] {12bebddb-e95d-4ae5-a05d-1b6bb60979c8} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:52.257391 [ 19252 ] {5893e4a2-516b-491d-908d-c86b407b64de} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:52.261731 [ 20355 ] {a05fcfc8-a9d6-4420-86ec-b1681a6bd5d3} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:44090) (comment: 01542_dictionary_load_exception_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:52.263479 [ 20355 ] {a05fcfc8-a9d6-4420-86ec-b1681a6bd5d3} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:52.347297 [ 20350 ] {2c7a98df-2b64-4a06-91c2-49239305b5a4} executeQuery: Code: 42. DB::Exception: Number of arguments for function multiply doesn't match: passed 0, should be 2: In scope SELECT max(multiply()). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:44040) (comment: 01323_bad_arg_in_arithmetic_operations.sql) (in query: SELECT max(multiply());), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x000000000ccd84e0 4. DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x000000000ccd2a84 5. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000ccd35cf 6. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000ccd3176 7. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000ccd4343 8. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000028399ff0 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000028367bce 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028366290 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2813: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000028391dce 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000028367bce 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028366290 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283b62c9 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002835ae03 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000028359104 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000028357f0d 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002921bdcc 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&) @ 0x000000002941f313 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&) @ 0x0000000029419aef 21. ./contrib/llvm-project/libcxx/include/vector:432: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000029421f5d 22. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000029344c1b 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*) @ 0x0000000029b3703b 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 25. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 26. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 30. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 31. asan_thread_start(void*) @ 0x000000000aa43059 2025.09.09 15:07:52.388099 [ 20350 ] {2c7a98df-2b64-4a06-91c2-49239305b5a4} TCPHandler: Code: 42. DB::Exception: Number of arguments for function multiply doesn't match: passed 0, should be 2: In scope SELECT max(multiply()). (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x000000000ccd84e0 4. DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x000000000ccd2a84 5. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000ccd35cf 6. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000ccd3176 7. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000ccd4343 8. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000028399ff0 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000028367bce 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028366290 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2813: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000028391dce 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000028367bce 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028366290 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283b62c9 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002835ae03 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000028359104 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000028357f0d 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002921bdcc 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&) @ 0x000000002941f313 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&) @ 0x0000000029419aef 21. ./contrib/llvm-project/libcxx/include/vector:432: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000029421f5d 22. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000029344c1b 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*) @ 0x0000000029b3703b 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 25. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 26. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 30. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 31. asan_thread_start(void*) @ 0x000000000aa43059 2025.09.09 15:07:52.452077 [ 3183 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:07:52.478597 [ 20350 ] {34caadec-1198-4f04-a51c-7dcd7929ee97} executeQuery: Code: 42. DB::Exception: Number of arguments for function multiply doesn't match: passed 3, should be 2: In scope SELECT min(multiply(1, 2, 3)). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:44040) (comment: 01323_bad_arg_in_arithmetic_operations.sql) (in query: SELECT min(multiply(1, 2 ,3));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x000000000ccd84e0 4. DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x000000000ccd2a84 5. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000ccd35cf 6. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000ccd3176 7. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000ccd4343 8. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000028399ff0 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000028367bce 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028366290 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2813: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000028391dce 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000028367bce 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028366290 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283b62c9 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002835ae03 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000028359104 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000028357f0d 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002921bdcc 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&) @ 0x000000002941f313 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&) @ 0x0000000029419aef 21. ./contrib/llvm-project/libcxx/include/vector:432: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000029421f5d 22. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000029344c1b 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*) @ 0x0000000029b3703b 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 25. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 26. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 30. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 31. asan_thread_start(void*) @ 0x000000000aa43059 2025.09.09 15:07:52.481505 [ 20350 ] {34caadec-1198-4f04-a51c-7dcd7929ee97} TCPHandler: Code: 42. DB::Exception: Number of arguments for function multiply doesn't match: passed 3, should be 2: In scope SELECT min(multiply(1, 2, 3)). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x000000000ccd84e0 4. DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x000000000ccd2a84 5. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000ccd35cf 6. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000ccd3176 7. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000ccd4343 8. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000028399ff0 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000028367bce 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028366290 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2813: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000028391dce 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000028367bce 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028366290 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283b62c9 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002835ae03 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000028359104 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000028357f0d 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002921bdcc 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&) @ 0x000000002941f313 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&) @ 0x0000000029419aef 21. ./contrib/llvm-project/libcxx/include/vector:432: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000029421f5d 22. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000029344c1b 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*) @ 0x0000000029b3703b 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 25. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 26. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 30. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 31. asan_thread_start(void*) @ 0x000000000aa43059 2025.09.09 15:07:52.630534 [ 20350 ] {47b8371e-7aa8-4159-aee2-262322968f73} executeQuery: Code: 42. DB::Exception: Number of arguments for function plus doesn't match: passed 0, should be 2: In scope SELECT sum(plus() + multiply()). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:44040) (comment: 01323_bad_arg_in_arithmetic_operations.sql) (in query: SELECT sum(plus() + multiply());), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x000000000ccd84e0 4. DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x000000000ccd2a84 5. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000ccd35cf 6. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000ccd3176 7. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000ccd4343 8. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000028399ff0 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000028367bce 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028366290 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2813: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000028391dce 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000028367bce 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028366290 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2813: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000028391dce 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000028367bce 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028366290 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283b62c9 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002835ae03 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000028359104 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000028357f0d 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002921bdcc 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&) @ 0x000000002941f313 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&) @ 0x0000000029419aef 24. ./contrib/llvm-project/libcxx/include/vector:432: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000029421f5d 25. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000029344c1b 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*) @ 0x0000000029b3703b 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 28. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 29. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 2025.09.09 15:07:52.635468 [ 20350 ] {47b8371e-7aa8-4159-aee2-262322968f73} TCPHandler: Code: 42. DB::Exception: Number of arguments for function plus doesn't match: passed 0, should be 2: In scope SELECT sum(plus() + multiply()). (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x000000000ccd84e0 4. DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x000000000ccd2a84 5. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000ccd35cf 6. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000ccd3176 7. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000ccd4343 8. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000028399ff0 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000028367bce 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028366290 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2813: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000028391dce 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000028367bce 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028366290 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2813: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000028391dce 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000028367bce 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028366290 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283b62c9 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002835ae03 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000028359104 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000028357f0d 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002921bdcc 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&) @ 0x000000002941f313 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&) @ 0x0000000029419aef 24. ./contrib/llvm-project/libcxx/include/vector:432: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000029421f5d 25. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000029344c1b 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*) @ 0x0000000029b3703b 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 28. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 29. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 2025.09.09 15:07:52.739669 [ 20350 ] {b5fe089b-4f5a-4c14-a51d-b57b6e6723b5} executeQuery: Code: 42. DB::Exception: Number of arguments for function multiply doesn't match: passed 1, should be 2: In scope SELECT sum((42 * 3) + multiply(42)). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:44040) (comment: 01323_bad_arg_in_arithmetic_operations.sql) (in query: SELECT sum(plus(multiply(42, 3), multiply(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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x000000000ccd84e0 4. DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x000000000ccd2a84 5. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000ccd35cf 6. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000ccd3176 7. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000ccd4343 8. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000028399ff0 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000028367bce 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028366290 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2813: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000028391dce 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000028367bce 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028366290 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2813: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000028391dce 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000028367bce 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028366290 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283b62c9 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002835ae03 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000028359104 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000028357f0d 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002921bdcc 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&) @ 0x000000002941f313 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&) @ 0x0000000029419aef 24. ./contrib/llvm-project/libcxx/include/vector:432: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000029421f5d 25. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000029344c1b 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*) @ 0x0000000029b3703b 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 28. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 29. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 2025.09.09 15:07:52.743710 [ 20350 ] {b5fe089b-4f5a-4c14-a51d-b57b6e6723b5} TCPHandler: Code: 42. DB::Exception: Number of arguments for function multiply doesn't match: passed 1, should be 2: In scope SELECT sum((42 * 3) + multiply(42)). (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x000000000ccd84e0 4. DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x000000000ccd2a84 5. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000ccd35cf 6. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000ccd3176 7. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000ccd4343 8. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000028399ff0 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000028367bce 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028366290 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2813: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000028391dce 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000028367bce 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028366290 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2813: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000028391dce 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000028367bce 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028366290 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283b62c9 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002835ae03 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000028359104 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000028357f0d 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002921bdcc 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&) @ 0x000000002941f313 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&) @ 0x0000000029419aef 24. ./contrib/llvm-project/libcxx/include/vector:432: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000029421f5d 25. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000029344c1b 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*) @ 0x0000000029b3703b 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 28. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 29. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 2025.09.09 15:07:52.824820 [ 3213 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:07:52.827646 [ 20849 ] {9a82ef70-c0da-4869-b801-cca6c7711db8} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:44174) (comment: 01542_dictionary_load_exception_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:52.828682 [ 19252 ] {7820949d-9959-4262-847a-46c5fad5ab40} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:44160) (comment: 01542_dictionary_load_exception_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:52.830839 [ 3222 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:07:52.831385 [ 19252 ] {7820949d-9959-4262-847a-46c5fad5ab40} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:52.834839 [ 2757 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:07:52.842651 [ 20849 ] {9a82ef70-c0da-4869-b801-cca6c7711db8} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:52.883991 [ 2688 ] {2743e0ec-d18c-42d3-957a-656e12080a13} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:44184) (comment: 01542_dictionary_load_exception_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:52.895375 [ 2688 ] {2743e0ec-d18c-42d3-957a-656e12080a13} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:52.911402 [ 20345 ] {4fbfdb57-c865-4ec1-a231-a2d254a8453f} executeQuery: Code: 42. DB::Exception: Number of arguments for function bitmapBuild doesn't match: passed 2, should be 1: In scope SELECT bitmapBuild(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT bitmapBuild(NULL, NULL);) 2025.09.09 15:07:52.913649 [ 20345 ] {4fbfdb57-c865-4ec1-a231-a2d254a8453f} TCPHandler: Code: 42. DB::Exception: Number of arguments for function bitmapBuild doesn't match: passed 2, should be 1: In scope SELECT bitmapBuild(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:07:52.924456 [ 20882 ] {f4bc3cad-a339-4ce9-b3f2-7052e90ad1b0} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:44196) (comment: 01542_dictionary_load_exception_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:52.934518 [ 20882 ] {f4bc3cad-a339-4ce9-b3f2-7052e90ad1b0} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:52.990680 [ 20338 ] {b22e7d83-70cd-456b-9cd8-36d32574f9c1} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:44206) (comment: 01542_dictionary_load_exception_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:52.992669 [ 20338 ] {b22e7d83-70cd-456b-9cd8-36d32574f9c1} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:53.013159 [ 20345 ] {1a9643f3-2f43-42a8-88bd-8d233b82d858} executeQuery: Code: 42. DB::Exception: Number of arguments for function bitmapCardinality doesn't match: passed 2, should be 1: In scope SELECT bitmapCardinality(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT bitmapCardinality(NULL, NULL);) 2025.09.09 15:07:53.023863 [ 20345 ] {1a9643f3-2f43-42a8-88bd-8d233b82d858} TCPHandler: Code: 42. DB::Exception: Number of arguments for function bitmapCardinality doesn't match: passed 2, should be 1: In scope SELECT bitmapCardinality(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:07:53.063559 [ 20350 ] {c5127bee-640e-406a-baf7-23dd4e8d403c} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:44240) (comment: 01542_dictionary_load_exception_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:53.064140 [ 20351 ] {c69709b0-c678-42c3-9ca8-5dfd9caaaa36} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:44250) (comment: 01542_dictionary_load_exception_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:53.067736 [ 20350 ] {c5127bee-640e-406a-baf7-23dd4e8d403c} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:53.084934 [ 20343 ] {90886193-3bf4-4e8a-a5e9-bc26daa84418} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:44220) (comment: 01542_dictionary_load_exception_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:53.091348 [ 20379 ] {b763d603-17a2-4151-aa2d-4868361af21c} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:44258) (comment: 01542_dictionary_load_exception_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:53.098517 [ 20343 ] {90886193-3bf4-4e8a-a5e9-bc26daa84418} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:53.098756 [ 20379 ] {b763d603-17a2-4151-aa2d-4868361af21c} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:53.110473 [ 20353 ] {e0d66953-9be1-412c-9ca6-2f0192dfccd4} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:44226) (comment: 01542_dictionary_load_exception_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:53.110926 [ 20351 ] {c69709b0-c678-42c3-9ca8-5dfd9caaaa36} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:53.122846 [ 20353 ] {e0d66953-9be1-412c-9ca6-2f0192dfccd4} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:53.132460 [ 20355 ] {98d90597-eb46-4d7a-b18e-edaed5ea1247} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:44272) (comment: 01542_dictionary_load_exception_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:53.138364 [ 20355 ] {98d90597-eb46-4d7a-b18e-edaed5ea1247} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:53.308825 [ 20380 ] {3437c316-01b8-4285-8510-cd6b89db4038} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:44270) (comment: 01542_dictionary_load_exception_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:53.314596 [ 20380 ] {3437c316-01b8-4285-8510-cd6b89db4038} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:53.457700 [ 3065 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:07:53.681395 [ 20849 ] {e73f8ca8-e5c8-412e-a00a-549b30d7b9a8} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:44278) (comment: 01542_dictionary_load_exception_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:53.694271 [ 20849 ] {e73f8ca8-e5c8-412e-a00a-549b30d7b9a8} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:53.713864 [ 20345 ] {a9ee6fab-c160-4686-b0b8-a5416737c24f} executeQuery: Code: 42. DB::Exception: Number of arguments for function bitmapMax doesn't match: passed 2, should be 1: In scope SELECT bitmapMax(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT bitmapMax(NULL, NULL);) 2025.09.09 15:07:53.730720 [ 20345 ] {a9ee6fab-c160-4686-b0b8-a5416737c24f} TCPHandler: Code: 42. DB::Exception: Number of arguments for function bitmapMax doesn't match: passed 2, should be 1: In scope SELECT bitmapMax(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:07:53.748546 [ 20338 ] {5e10022b-c002-40db-8ba1-feb0f0f927b5} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:44306) (comment: 01542_dictionary_load_exception_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:53.750707 [ 20338 ] {5e10022b-c002-40db-8ba1-feb0f0f927b5} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:53.782218 [ 2688 ] {c9ee4a7e-2c7b-4ef3-adaa-6cbc79e74027} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:44286) (comment: 01542_dictionary_load_exception_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:53.789160 [ 2688 ] {c9ee4a7e-2c7b-4ef3-adaa-6cbc79e74027} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:53.827088 [ 2809 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:07:53.832866 [ 2843 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:07:53.841052 [ 2833 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:07:53.869001 [ 20882 ] {fbe6279e-1a14-4e3c-b57a-b5205cdae7c7} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:44302) (comment: 01542_dictionary_load_exception_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:53.879444 [ 20882 ] {fbe6279e-1a14-4e3c-b57a-b5205cdae7c7} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:53.888526 [ 20345 ] {141bc822-ddf9-4a3a-bac6-9214e93f50d0} executeQuery: Code: 42. DB::Exception: Number of arguments for function bitmapMin doesn't match: passed 2, should be 1: In scope SELECT bitmapMin(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT bitmapMin(NULL, NULL);) 2025.09.09 15:07:53.892966 [ 20345 ] {141bc822-ddf9-4a3a-bac6-9214e93f50d0} TCPHandler: Code: 42. DB::Exception: Number of arguments for function bitmapMin doesn't match: passed 2, should be 1: In scope SELECT bitmapMin(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:07:53.915773 [ 20343 ] {49570451-d60b-49a8-9696-ed793c39e727} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:44310) (comment: 01542_dictionary_load_exception_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:53.927063 [ 20343 ] {49570451-d60b-49a8-9696-ed793c39e727} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:53.974271 [ 20353 ] {6c51331f-08b6-423a-9a09-00cb713054b5} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:44318) (comment: 01542_dictionary_load_exception_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:53.982532 [ 20353 ] {6c51331f-08b6-423a-9a09-00cb713054b5} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:53.999406 [ 20350 ] {1d647dbd-81b0-4a7a-b8dd-275373d7dc83} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:44334) (comment: 01542_dictionary_load_exception_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:54.003535 [ 20350 ] {1d647dbd-81b0-4a7a-b8dd-275373d7dc83} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:54.063754 [ 20849 ] {6c0d5fc1-cf1c-4bff-aad8-eafabffd0497} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:44356) (comment: 01542_dictionary_load_exception_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:54.067207 [ 20849 ] {6c0d5fc1-cf1c-4bff-aad8-eafabffd0497} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:54.077754 [ 20351 ] {7c028649-1e4d-489b-825a-bacfaabe97b8} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:44350) (comment: 01542_dictionary_load_exception_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:54.098234 [ 20351 ] {7c028649-1e4d-489b-825a-bacfaabe97b8} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:54.209299 [ 20380 ] {6d54eecd-26cd-4974-b81a-9fb3063a28f6} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:44370) (comment: 01542_dictionary_load_exception_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:54.217424 [ 20379 ] {ffafb821-a7e7-4487-ace2-6711d4c5d0cb} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:44362) (comment: 01542_dictionary_load_exception_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:54.219763 [ 20379 ] {ffafb821-a7e7-4487-ace2-6711d4c5d0cb} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:54.226327 [ 20380 ] {6d54eecd-26cd-4974-b81a-9fb3063a28f6} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:54.329388 [ 2688 ] {5f50d8b8-34e9-4fa7-a031-852e2f5e5553} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:44380) (comment: 01542_dictionary_load_exception_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:54.366979 [ 20345 ] {4fc06238-1480-4473-9b87-8682ca15a84f} executeQuery: Code: 42. DB::Exception: Number of arguments for function bitmapSubsetInRange doesn't match: passed 2, should be 3: In scope SELECT bitmapSubsetInRange(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT bitmapSubsetInRange(NULL, NULL);) 2025.09.09 15:07:54.394363 [ 20345 ] {4fc06238-1480-4473-9b87-8682ca15a84f} TCPHandler: Code: 42. DB::Exception: Number of arguments for function bitmapSubsetInRange doesn't match: passed 2, should be 3: In scope SELECT bitmapSubsetInRange(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:07:54.338151 [ 2688 ] {5f50d8b8-34e9-4fa7-a031-852e2f5e5553} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:54.459525 [ 2904 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:07:54.508009 [ 20345 ] {800dda80-1500-4c9b-b151-bbc74540a917} executeQuery: Code: 42. DB::Exception: Number of arguments for function bitmapSubsetLimit doesn't match: passed 2, should be 3: In scope SELECT bitmapSubsetLimit(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT bitmapSubsetLimit(NULL, NULL);) 2025.09.09 15:07:54.523838 [ 20345 ] {800dda80-1500-4c9b-b151-bbc74540a917} TCPHandler: Code: 42. DB::Exception: Number of arguments for function bitmapSubsetLimit doesn't match: passed 2, should be 3: In scope SELECT bitmapSubsetLimit(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:07:54.555257 [ 20882 ] {7b011424-f705-430d-8cbe-3f31d57c4808} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:44396) (comment: 01542_dictionary_load_exception_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:54.557514 [ 20882 ] {7b011424-f705-430d-8cbe-3f31d57c4808} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:54.596815 [ 20338 ] {669c4dcb-71c2-4068-8219-c51c791da1d7} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:44402) (comment: 01542_dictionary_load_exception_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:54.606813 [ 20849 ] {66e8c6fe-b2c8-4f19-8c9c-3792ce1a08f6} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:44390) (comment: 01542_dictionary_load_exception_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:54.607470 [ 20338 ] {669c4dcb-71c2-4068-8219-c51c791da1d7} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:54.617776 [ 20849 ] {66e8c6fe-b2c8-4f19-8c9c-3792ce1a08f6} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:54.621429 [ 20345 ] {3878b5d0-61fa-4af5-bfc6-8371bf19bb0f} executeQuery: Code: 42. DB::Exception: Number of arguments for function bitmapToArray doesn't match: passed 2, should be 1: In scope SELECT bitmapToArray(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT bitmapToArray(NULL, NULL);) 2025.09.09 15:07:54.627703 [ 3494 ] {} test_0473czib.mt (37fd3cf2-879f-4934-ac8d-662471988a31): dropAllData: got exception removing parts from disk, removing successfully removed parts from memory. 2025.09.09 15:07:54.632472 [ 20345 ] {3878b5d0-61fa-4af5-bfc6-8371bf19bb0f} TCPHandler: Code: 42. DB::Exception: Number of arguments for function bitmapToArray doesn't match: passed 2, should be 1: In scope SELECT bitmapToArray(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:07:54.636300 [ 3494 ] {} DatabaseCatalog: Cannot drop table test_0473czib.mt (37fd3cf2-879f-4934-ac8d-662471988a31). 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af819ed 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80746 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000263a174e 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002c47c445 8. ./contrib/llvm-project/libcxx/include/vector:547: DB::MergeTreeData::clearPartsFromFilesystem(std::vector, std::allocator>> const&, bool, std::unordered_set, std::equal_to, std::allocator>*) @ 0x000000002c47a78e 9. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::dropAllData() @ 0x000000002c4862d9 10. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::dropTableFinally(DB::DatabaseCatalog::TableMarkedAsDropped const&) @ 0x00000000286c7c77 11. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: void std::__function::__policy_invoker::__call_impl, std::allocator>>)::$_0, void ()>>(std::__function::__policy_storage const*) @ 0x00000000286d9744 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000263a3ea5 13. ./contrib/llvm-project/libcxx/include/future:0: std::packaged_task::operator()() @ 0x000000001bba33ac 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7eaf0 15. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001af8a79f 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 18. asan_thread_start(void*) @ 0x000000000aa43059 19. ? @ 0x00007f35aab92ac3 20. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:07:54.692998 [ 20345 ] {3707350b-e6b5-49d4-8d8a-521e2a16f067} executeQuery: Code: 42. DB::Exception: Number of arguments for function bitmapTransform doesn't match: passed 2, should be 3: In scope SELECT bitmapTransform(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT bitmapTransform(NULL, NULL);) 2025.09.09 15:07:54.711856 [ 20345 ] {3707350b-e6b5-49d4-8d8a-521e2a16f067} TCPHandler: Code: 42. DB::Exception: Number of arguments for function bitmapTransform doesn't match: passed 2, should be 3: In scope SELECT bitmapTransform(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:07:54.782092 [ 2688 ] {9057df74-ea7f-4077-a309-0020e0473b2c} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:44410) (comment: 01542_dictionary_load_exception_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:54.790394 [ 2688 ] {9057df74-ea7f-4077-a309-0020e0473b2c} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:54.822725 [ 20351 ] {2257ddbb-c579-4409-ae9c-1b1abc740f22} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:44436) (comment: 01542_dictionary_load_exception_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:54.824680 [ 20351 ] {2257ddbb-c579-4409-ae9c-1b1abc740f22} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:54.831563 [ 20350 ] {f70baf7b-c1f4-4e43-8cc8-ab5c521ef4ea} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:44424) (comment: 01542_dictionary_load_exception_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:54.831810 [ 2916 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:07:54.833334 [ 20350 ] {f70baf7b-c1f4-4e43-8cc8-ab5c521ef4ea} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:54.839277 [ 2940 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:07:54.842916 [ 2915 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:07:54.846041 [ 20343 ] {59b8fe27-a15a-4d7e-9f18-58d8b2502cde} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:44412) (comment: 01542_dictionary_load_exception_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:54.852176 [ 20343 ] {59b8fe27-a15a-4d7e-9f18-58d8b2502cde} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:54.856324 [ 20353 ] {bbfc7a40-680d-47fb-9124-bac47f93aa71} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:44416) (comment: 01542_dictionary_load_exception_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:54.858132 [ 20353 ] {bbfc7a40-680d-47fb-9124-bac47f93aa71} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:54.946789 [ 20379 ] {2e549408-07e7-489e-ace5-276b02fc0082} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:44440) (comment: 01542_dictionary_load_exception_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:54.954892 [ 20379 ] {2e549408-07e7-489e-ace5-276b02fc0082} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:55.108206 [ 20380 ] {70f27c06-dbd2-4173-88c5-ac67ed9fd5c9} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:44448) (comment: 01542_dictionary_load_exception_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:55.114413 [ 20380 ] {70f27c06-dbd2-4173-88c5-ac67ed9fd5c9} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:55.124684 [ 20355 ] {352f454b-4991-4a58-8d69-18b34111a78f} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:44456) (comment: 01542_dictionary_load_exception_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:55.129484 [ 20355 ] {352f454b-4991-4a58-8d69-18b34111a78f} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:55.259912 [ 20345 ] {daa22007-7f3c-494a-ac54-d0ed7598d148} executeQuery: Code: 42. DB::Exception: Number of arguments for function bitmaskToArray doesn't match: passed 2, should be 1: In scope SELECT bitmaskToArray(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT bitmaskToArray(NULL, NULL);) 2025.09.09 15:07:55.283661 [ 20345 ] {daa22007-7f3c-494a-ac54-d0ed7598d148} TCPHandler: Code: 42. DB::Exception: Number of arguments for function bitmaskToArray doesn't match: passed 2, should be 1: In scope SELECT bitmaskToArray(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:07:55.285094 [ 20350 ] {e18e89e5-4c88-431b-83b4-c68bab9d7850} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:44472) (comment: 01542_dictionary_load_exception_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:55.293093 [ 20350 ] {e18e89e5-4c88-431b-83b4-c68bab9d7850} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:55.298228 [ 20353 ] {711a0817-087e-4896-84c5-21fbb0e022df} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:44466) (comment: 01542_dictionary_load_exception_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:55.300331 [ 20353 ] {711a0817-087e-4896-84c5-21fbb0e022df} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:55.325962 [ 20351 ] {0827c1d0-6099-4b13-a5f7-21222b8d1c1b} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:44478) (comment: 01542_dictionary_load_exception_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:55.354371 [ 20351 ] {0827c1d0-6099-4b13-a5f7-21222b8d1c1b} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:55.373082 [ 20379 ] {e9222d67-856f-497e-af72-c994094c1f18} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:44480) (comment: 01542_dictionary_load_exception_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:55.422826 [ 20345 ] {f3abac15-3db3-445c-9e87-07d73f7f3bda} executeQuery: Code: 42. DB::Exception: Number of arguments for function bitmaskToList doesn't match: passed 2, should be 1: In scope SELECT bitmaskToList(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT bitmaskToList(NULL, NULL);) 2025.09.09 15:07:55.467925 [ 2993 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:07:55.475121 [ 20379 ] {e9222d67-856f-497e-af72-c994094c1f18} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:55.482686 [ 20345 ] {f3abac15-3db3-445c-9e87-07d73f7f3bda} TCPHandler: Code: 42. DB::Exception: Number of arguments for function bitmaskToList doesn't match: passed 2, should be 1: In scope SELECT bitmaskToList(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:07:55.549425 [ 20345 ] {d7e8e385-2573-4201-b59d-c54f3969532a} executeQuery: Code: 42. DB::Exception: Number of arguments for function blockNumber doesn't match: passed 2, should be 0: In scope SELECT blockNumber(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT blockNumber(NULL, NULL);) 2025.09.09 15:07:55.574059 [ 20345 ] {d7e8e385-2573-4201-b59d-c54f3969532a} TCPHandler: Code: 42. DB::Exception: Number of arguments for function blockNumber doesn't match: passed 2, should be 0: In scope SELECT blockNumber(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:07:55.668189 [ 20350 ] {cef592fc-7769-4724-b85f-d1db07b45076} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:44488) (comment: 01542_dictionary_load_exception_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:55.669306 [ 20380 ] {f5796ec6-4c03-4f0d-bac5-96bfa2424c9d} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:44500) (comment: 01542_dictionary_load_exception_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:55.669941 [ 20350 ] {cef592fc-7769-4724-b85f-d1db07b45076} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:55.682425 [ 20380 ] {f5796ec6-4c03-4f0d-bac5-96bfa2424c9d} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:55.691344 [ 2687 ] {c1c7f86e-2a8e-4a59-8832-c3157f9b3f8d} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:44522) (comment: 01542_dictionary_load_exception_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:55.692315 [ 20353 ] {582d9f28-e16d-4bb6-96dc-24292fb0a0c5} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:44484) (comment: 01542_dictionary_load_exception_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:55.698473 [ 2687 ] {c1c7f86e-2a8e-4a59-8832-c3157f9b3f8d} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:55.705015 [ 20353 ] {582d9f28-e16d-4bb6-96dc-24292fb0a0c5} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:55.731379 [ 20355 ] {103e6a77-a1ce-41f3-b5b7-e75c94106b5e} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:44514) (comment: 01542_dictionary_load_exception_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:55.763686 [ 20355 ] {103e6a77-a1ce-41f3-b5b7-e75c94106b5e} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:55.837052 [ 3053 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:07:55.842790 [ 3025 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:07:55.844829 [ 3025 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:07:55.920062 [ 20345 ] {508fd9d7-179d-4fa9-b9a8-8bd28df661b9} executeQuery: Code: 42. DB::Exception: Number of arguments for function blockSize doesn't match: passed 2, should be 0: In scope SELECT blockSize(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT blockSize(NULL, NULL);) 2025.09.09 15:07:55.947525 [ 20345 ] {508fd9d7-179d-4fa9-b9a8-8bd28df661b9} TCPHandler: Code: 42. DB::Exception: Number of arguments for function blockSize doesn't match: passed 2, should be 0: In scope SELECT blockSize(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:07:56.093706 [ 20351 ] {13141430-db58-4279-b1f4-b582c13b2f23} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:44528) (comment: 01542_dictionary_load_exception_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:56.104622 [ 20351 ] {13141430-db58-4279-b1f4-b582c13b2f23} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:56.113131 [ 3340 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {1e64423d-b43b-45ea-b85e-a97c07ea6431::202509_1_138_27}: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=13, 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af80b71 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80746 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002c765aab 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:1197: ? @ 0x000000002c7602b8 8. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x000000002c75fc2b 9. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:0: DB::MergeTreeReaderCompact::MergeTreeReaderCompact(std::shared_ptr, DB::NamesAndTypesList, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*, DB::MarkCache*, DB::MarkRanges, DB::MergeTreeReaderSettings, std::map, std::allocator>>, std::function const&, int) @ 0x000000002c7aee03 10. ./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.h:16: DB::MergeTreeReaderCompactSingleBuffer::MergeTreeReaderCompactSingleBuffer&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int&&) @ 0x000000002c5d6d21 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::MergeTreeDataPartCompact::getReader(DB::NamesAndTypesList const&, std::shared_ptr const&, DB::MarkRanges const&, std::unordered_map, std::equal_to, std::allocator>> const&, DB::UncompressedCache*, DB::MarkCache*, std::shared_ptr const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) const @ 0x000000002c5d1037 12. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:169: DB::MergeTreeSequentialSource::MergeTreeSequentialSource(DB::MergeTreeSequentialSourceType, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::vector>, std::optional, bool, bool, bool) @ 0x000000002c80c330 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:35: DB::MergeTreeSequentialSource* std::construct_at[abi:v15007] const&, std::shared_ptr&, std::shared_ptr&, std::vector>&, std::optional, bool, bool&, bool&, DB::MergeTreeSequentialSource*>(DB::MergeTreeSequentialSource*, DB::MergeTreeSequentialSourceType&, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr&, std::shared_ptr&, std::vector>&, std::optional&&, bool&&, bool&, bool&) @ 0x000000002c81320f 14. ./contrib/llvm-project/libcxx/include/__memory/allocator_traits.h:298: DB::createMergeTreeSequentialSource(DB::MergeTreeSequentialSourceType, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::vector>, std::optional, std::shared_ptr>, bool, bool, bool) @ 0x000000002c810812 15. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1136: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::createMergedStream() @ 0x000000002c3dd079 16. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() @ 0x000000002c3d6516 17. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:534: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x000000002c3e2799 18. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::execute() @ 0x000000002c3ef3fe 19. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:0: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000002cc2f4c0 20. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000002c427f28 21. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000002c429675 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7eaf0 23. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001af8a79f 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 26. asan_thread_start(void*) @ 0x000000000aa43059 27. ? @ 0x00007f35aab92ac3 28. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:07:56.117176 [ 20350 ] {cabc697d-f9fa-456a-8777-10c6f0ca1b29} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:44544) (comment: 01542_dictionary_load_exception_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:56.119152 [ 20350 ] {cabc697d-f9fa-456a-8777-10c6f0ca1b29} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:56.124360 [ 20379 ] {c4c967a4-804a-4429-8bb3-a01f03f7644c} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:44570) (comment: 01542_dictionary_load_exception_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:56.130554 [ 20379 ] {c4c967a4-804a-4429-8bb3-a01f03f7644c} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:56.138598 [ 20353 ] {5a734539-afee-46db-80a6-ba681efb1666} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:44556) (comment: 01542_dictionary_load_exception_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:56.145864 [ 20353 ] {5a734539-afee-46db-80a6-ba681efb1666} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:56.172536 [ 20355 ] {a3e99fca-ff0b-4359-abe4-5297de5a2930} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:44588) (comment: 01542_dictionary_load_exception_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:56.196036 [ 20355 ] {a3e99fca-ff0b-4359-abe4-5297de5a2930} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:56.216348 [ 20345 ] {2ff90a18-5627-407d-ac76-6661cd659a3a} executeQuery: Code: 42. DB::Exception: Number of arguments for function buildId doesn't match: passed 2, should be 0: In scope SELECT buildId(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT buildId(NULL, NULL);) 2025.09.09 15:07:56.226679 [ 20380 ] {f3bd8d79-3135-41b0-a9d1-952f9188ddcf} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:44572) (comment: 01542_dictionary_load_exception_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:56.227084 [ 20345 ] {2ff90a18-5627-407d-ac76-6661cd659a3a} TCPHandler: Code: 42. DB::Exception: Number of arguments for function buildId doesn't match: passed 2, should be 0: In scope SELECT buildId(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:07:56.228388 [ 20380 ] {f3bd8d79-3135-41b0-a9d1-952f9188ddcf} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:56.305030 [ 2687 ] {521148d7-badc-4e1c-bc7f-1bb5d4c9e38c} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:44594) (comment: 01542_dictionary_load_exception_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:56.312428 [ 2687 ] {521148d7-badc-4e1c-bc7f-1bb5d4c9e38c} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:56.438206 [ 20350 ] {f1630ff6-a1ff-4bb3-b2e9-912687ae570e} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:44608) (comment: 01542_dictionary_load_exception_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:56.445794 [ 20350 ] {f1630ff6-a1ff-4bb3-b2e9-912687ae570e} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:56.470858 [ 3102 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:07:56.530542 [ 20353 ] {8c77df62-198f-46aa-8bf5-8f5676c400b7} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:44616) (comment: 01542_dictionary_load_exception_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:56.532829 [ 20353 ] {8c77df62-198f-46aa-8bf5-8f5676c400b7} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:56.547948 [ 20379 ] {e4413bdc-d9da-4861-ae36-dd477f93b016} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:44632) (comment: 01542_dictionary_load_exception_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:56.549913 [ 20379 ] {e4413bdc-d9da-4861-ae36-dd477f93b016} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:56.554556 [ 20351 ] {c86fff19-754e-4b37-917a-5236d23c4753} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:44618) (comment: 01542_dictionary_load_exception_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:56.558469 [ 20351 ] {c86fff19-754e-4b37-917a-5236d23c4753} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:56.588640 [ 20380 ] {441389a2-9b5c-4ee2-8b08-d6143c75f945} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:44638) (comment: 01542_dictionary_load_exception_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:56.591013 [ 20380 ] {441389a2-9b5c-4ee2-8b08-d6143c75f945} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:56.836757 [ 20345 ] {30e21dd9-c0fa-4c99-bf84-1ab9844cba7a} executeQuery: Code: 42. DB::Exception: Number of arguments for function byteSwap doesn't match: passed 2, should be 1: In scope SELECT byteSwap(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT byteSwap(NULL, NULL);) 2025.09.09 15:07:56.838934 [ 3163 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:07:56.839702 [ 20345 ] {30e21dd9-c0fa-4c99-bf84-1ab9844cba7a} TCPHandler: Code: 42. DB::Exception: Number of arguments for function byteSwap doesn't match: passed 2, should be 1: In scope SELECT byteSwap(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:07:56.845210 [ 3145 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:07:56.846576 [ 3146 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:07:56.862642 [ 20353 ] {f55f035f-af1e-44cd-9b13-4c1917af2e2f} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:44644) (comment: 01542_dictionary_load_exception_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:56.864502 [ 20353 ] {f55f035f-af1e-44cd-9b13-4c1917af2e2f} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:56.901588 [ 20351 ] {5e5146f9-59be-4022-900e-2b8712202153} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:44656) (comment: 01542_dictionary_load_exception_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:56.910734 [ 20351 ] {5e5146f9-59be-4022-900e-2b8712202153} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:56.914795 [ 20350 ] {bc8a38d4-9219-4918-9acc-d2f13f1106c1} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:44650) (comment: 01542_dictionary_load_exception_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:56.917152 [ 20350 ] {bc8a38d4-9219-4918-9acc-d2f13f1106c1} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:56.938668 [ 20379 ] {ebc858be-416a-42e2-89d0-c803f153f64c} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:44660) (comment: 01542_dictionary_load_exception_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:56.953282 [ 20379 ] {ebc858be-416a-42e2-89d0-c803f153f64c} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:56.953756 [ 20380 ] {2ffaf157-7a7b-4887-bd31-6eb79351ef1d} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:44676) (comment: 01542_dictionary_load_exception_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:56.958692 [ 20380 ] {2ffaf157-7a7b-4887-bd31-6eb79351ef1d} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:57.134781 [ 19252 ] {7a092a82-69d9-42cf-b672-67b13645b690} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=790, jobs=740). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:44274) (comment: 02382_join_and_filtering_set.sql) (in query: SELECT count() FROM t1 JOIN t2 ON t1.x = t2.x WHERE t1.y % 2 == 0 AND t2.y % 2 == 0;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af872f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af7b2d1 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af7c3f3 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d36920d 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000002d369e5f 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processOrdinaryQuery() @ 0x000000002d18af7b 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d17644a 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 15. asan_thread_start(void*) @ 0x000000000aa43059 16. ? @ 0x00007f35aab92ac3 17. ? @ 0x00007f35aac24850 2025.09.09 15:07:57.141587 [ 19252 ] {7a092a82-69d9-42cf-b672-67b13645b690} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=790, jobs=740). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af872f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af7b2d1 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af7c3f3 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d36920d 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000002d369e5f 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processOrdinaryQuery() @ 0x000000002d18af7b 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d17644a 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 15. asan_thread_start(void*) @ 0x000000000aa43059 16. ? @ 0x00007f35aab92ac3 17. ? @ 0x00007f35aac24850 2025.09.09 15:07:57.157781 [ 20355 ] {d172f949-464c-4efe-b148-0e7b1397513c} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:44678) (comment: 01542_dictionary_load_exception_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:57.159723 [ 20355 ] {d172f949-464c-4efe-b148-0e7b1397513c} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:57.209002 [ 2687 ] {b01e6ee4-1fc7-4428-ad45-122952b6ff7b} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:44690) (comment: 01542_dictionary_load_exception_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:57.211045 [ 20345 ] {75ccfc9c-512d-4da5-89a6-2da051746401} executeQuery: Code: 42. DB::Exception: Invalid number of arguments for function multiIf: In scope SELECT caseWithoutExpr(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT caseWithoutExpr(NULL, NULL);) 2025.09.09 15:07:57.218875 [ 2687 ] {b01e6ee4-1fc7-4428-ad45-122952b6ff7b} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:57.224979 [ 20345 ] {75ccfc9c-512d-4da5-89a6-2da051746401} TCPHandler: Code: 42. DB::Exception: Invalid number of arguments for function multiIf: In scope SELECT caseWithoutExpr(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:07:57.249307 [ 20884 ] {9fa66842-d833-4a5a-8ec0-87f28aba52aa} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:44700) (comment: 01542_dictionary_load_exception_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:57.253792 [ 20884 ] {9fa66842-d833-4a5a-8ec0-87f28aba52aa} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:57.296363 [ 3612 ] {50f9adf1-87d7-448e-87d4-cf39dbcb5ef5} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:44702) (comment: 01542_dictionary_load_exception_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:57.302061 [ 3612 ] {50f9adf1-87d7-448e-87d4-cf39dbcb5ef5} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:57.328293 [ 20345 ] {866570b4-97c9-4e75-9199-7c655453513f} executeQuery: Code: 42. DB::Exception: Invalid number of arguments for function multiIf: In scope SELECT caseWithoutExpression(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT caseWithoutExpression(NULL, NULL);) 2025.09.09 15:07:57.340749 [ 20345 ] {866570b4-97c9-4e75-9199-7c655453513f} TCPHandler: Code: 42. DB::Exception: Invalid number of arguments for function multiIf: In scope SELECT caseWithoutExpression(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:07:57.351424 [ 20165 ] {} ExternalDictionariesLoader: Could not load external dictionary 'b9456353-118f-4e69-ac1b-88d4f6a6e618', next update is scheduled at 2025-09-09 15:08:03: 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:07:57.369888 [ 20849 ] {c6d5f986-da67-40c8-b85d-8d90f854c33b} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:44716) (comment: 01542_dictionary_load_exception_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:57.377241 [ 20849 ] {c6d5f986-da67-40c8-b85d-8d90f854c33b} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:57.386566 [ 20881 ] {946920ab-efae-43b0-8fca-01042760585f} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:44708) (comment: 01542_dictionary_load_exception_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:57.391484 [ 20881 ] {946920ab-efae-43b0-8fca-01042760585f} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:57.406808 [ 3722 ] {9fe5db15-05f9-47d0-ad19-b8d590ba90db} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:44710) (comment: 01542_dictionary_load_exception_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:57.416130 [ 3722 ] {9fe5db15-05f9-47d0-ad19-b8d590ba90db} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:57.478431 [ 3237 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:07:57.603962 [ 20345 ] {48fc8181-d4ec-4b95-9e41-7ec45ee902b5} executeQuery: Code: 43. DB::Exception: Illegal type Nullable(Nothing) of first argument of function catboostEvaluate, expected a string.: In scope SELECT catboostEvaluate(NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT catboostEvaluate(NULL, NULL);) 2025.09.09 15:07:57.615499 [ 20345 ] {48fc8181-d4ec-4b95-9e41-7ec45ee902b5} TCPHandler: Code: 43. DB::Exception: Illegal type Nullable(Nothing) of first argument of function catboostEvaluate, expected a string.: In scope SELECT catboostEvaluate(NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.09.09 15:07:57.711078 [ 20355 ] {ad0bdd33-e566-45f8-b25d-9da17efc7be8} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:44732) (comment: 01542_dictionary_load_exception_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:57.712852 [ 20355 ] {ad0bdd33-e566-45f8-b25d-9da17efc7be8} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:57.719456 [ 20345 ] {fca57285-9767-468b-b7b1-1c0f28df48d1} executeQuery: Code: 43. DB::Exception: All the arguments of aggregate function categoricalInformationValue should be UInt8. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT categoricalInformationValue(NULL, NULL);) 2025.09.09 15:07:57.724480 [ 2687 ] {d2f1a53d-3945-4a1f-86a7-c39d852a4ebc} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:44738) (comment: 01542_dictionary_load_exception_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:57.726204 [ 20884 ] {5434a3ac-0755-4140-9706-1f622af2c643} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=790, jobs=739). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:44754) (comment: 01542_dictionary_load_exception_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af872f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af7b2d1 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af7c3f3 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d36920d 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000002d369e5f 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processOrdinaryQuery() @ 0x000000002d18af7b 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d17644a 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 15. asan_thread_start(void*) @ 0x000000000aa43059 16. ? @ 0x00007f35aab92ac3 17. ? @ 0x00007f35aac24850 2025.09.09 15:07:57.734766 [ 2687 ] {d2f1a53d-3945-4a1f-86a7-c39d852a4ebc} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:57.735572 [ 20884 ] {5434a3ac-0755-4140-9706-1f622af2c643} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=790, 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af872f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af7b2d1 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af7c3f3 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d36920d 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000002d369e5f 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processOrdinaryQuery() @ 0x000000002d18af7b 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d17644a 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 15. asan_thread_start(void*) @ 0x000000000aa43059 16. ? @ 0x00007f35aab92ac3 17. ? @ 0x00007f35aac24850 2025.09.09 15:07:57.754846 [ 20881 ] {155c0577-1d96-4b97-950b-4b4b11f691b7} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:44774) (comment: 01542_dictionary_load_exception_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:57.756521 [ 20881 ] {155c0577-1d96-4b97-950b-4b4b11f691b7} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:57.756321 [ 3612 ] {f0c383ed-afcd-443d-82c4-b00d8f58e2c6} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:44768) (comment: 01542_dictionary_load_exception_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:57.766794 [ 3612 ] {f0c383ed-afcd-443d-82c4-b00d8f58e2c6} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:57.818860 [ 20345 ] {fca57285-9767-468b-b7b1-1c0f28df48d1} TCPHandler: Code: 43. DB::Exception: All the arguments of aggregate function categoricalInformationValue should be UInt8. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.09.09 15:07:57.840417 [ 3220 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:07:57.853673 [ 2748 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:07:57.853827 [ 3235 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:07:57.915025 [ 20345 ] {afa76311-aeda-4428-a56c-ec140a249d0b} executeQuery: Code: 42. DB::Exception: Number of arguments for function cbrt doesn't match: passed 2, should be 1: In scope SELECT cbrt(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT cbrt(NULL, NULL);) 2025.09.09 15:07:57.946439 [ 20345 ] {afa76311-aeda-4428-a56c-ec140a249d0b} TCPHandler: Code: 42. DB::Exception: Number of arguments for function cbrt doesn't match: passed 2, should be 1: In scope SELECT cbrt(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:07:58.182434 [ 3722 ] {febd471f-d5e9-4f27-a2f5-16ed63896e0e} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:44780) (comment: 01542_dictionary_load_exception_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:58.182477 [ 20355 ] {bed67faf-aed9-484e-9c5d-d469205e35ae} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:44782) (comment: 01542_dictionary_load_exception_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:58.184678 [ 3722 ] {febd471f-d5e9-4f27-a2f5-16ed63896e0e} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:58.190442 [ 20355 ] {bed67faf-aed9-484e-9c5d-d469205e35ae} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:58.220375 [ 20849 ] {e2fd6952-893d-42e1-bc95-07de92da5bfd} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:58068) (comment: 01542_dictionary_load_exception_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:58.220898 [ 3612 ] {9d7ab9a8-a69f-418d-b7e8-859ecbd344f7} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:58042) (comment: 01542_dictionary_load_exception_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:58.222396 [ 20849 ] {e2fd6952-893d-42e1-bc95-07de92da5bfd} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:58.229914 [ 20881 ] {af62ae1c-b2a6-4a6c-bc83-0b810e7c7096} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:58052) (comment: 01542_dictionary_load_exception_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:58.237150 [ 20881 ] {af62ae1c-b2a6-4a6c-bc83-0b810e7c7096} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:58.237463 [ 20884 ] {24edc5eb-3bcb-41df-be0d-94df46c2eb54} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:44806) (comment: 01542_dictionary_load_exception_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:58.241500 [ 20884 ] {24edc5eb-3bcb-41df-be0d-94df46c2eb54} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:58.286525 [ 3612 ] {9d7ab9a8-a69f-418d-b7e8-859ecbd344f7} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:58.441834 [ 2688 ] {f9217aa9-89e4-4cf8-8727-1296dab2709a} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:58078) (comment: 01542_dictionary_load_exception_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:58.450364 [ 2688 ] {f9217aa9-89e4-4cf8-8727-1296dab2709a} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:58.481079 [ 2864 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:07:58.578118 [ 20355 ] {f0294720-ce27-4571-a63a-9e388f5ef2ad} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:58094) (comment: 01542_dictionary_load_exception_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:58.579905 [ 20355 ] {f0294720-ce27-4571-a63a-9e388f5ef2ad} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:58.621297 [ 20881 ] {940c3baa-5cfe-4ed6-90ef-866f8f6fa003} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:58112) (comment: 01542_dictionary_load_exception_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:58.630324 [ 20884 ] {183f1058-f6b6-4f50-bb75-53c2690e3e2e} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:58098) (comment: 01542_dictionary_load_exception_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:58.630447 [ 20881 ] {940c3baa-5cfe-4ed6-90ef-866f8f6fa003} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:58.632288 [ 20884 ] {183f1058-f6b6-4f50-bb75-53c2690e3e2e} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:58.649260 [ 3612 ] {552b3890-e339-47ae-8745-369702cabeb7} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:58124) (comment: 01542_dictionary_load_exception_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:58.651054 [ 3612 ] {552b3890-e339-47ae-8745-369702cabeb7} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:58.695553 [ 3722 ] {50746291-8a19-4c97-81ff-65cce8d53354} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:58126) (comment: 01542_dictionary_load_exception_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:58.716216 [ 3722 ] {50746291-8a19-4c97-81ff-65cce8d53354} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:58.842742 [ 2893 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:07:58.855819 [ 2897 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:07:58.862039 [ 2814 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:07:59.021787 [ 20355 ] {4fa7ccaf-4cdb-45ff-97af-d443b5fd40ff} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:58134) (comment: 01542_dictionary_load_exception_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:59.034776 [ 20355 ] {4fa7ccaf-4cdb-45ff-97af-d443b5fd40ff} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:59.038984 [ 20881 ] {4497bb63-b86d-4f3e-a2b8-0607ad7b248e} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:58156) (comment: 01542_dictionary_load_exception_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:59.039329 [ 20884 ] {0a9bbf4d-b262-409b-b677-ee3a4c3edc8c} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:58138) (comment: 01542_dictionary_load_exception_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:59.045114 [ 20881 ] {4497bb63-b86d-4f3e-a2b8-0607ad7b248e} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:59.050022 [ 20884 ] {0a9bbf4d-b262-409b-b677-ee3a4c3edc8c} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:59.053683 [ 3612 ] {d860595f-a9c1-4e0d-82bc-41615a04cdaf} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:58150) (comment: 01542_dictionary_load_exception_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:59.062511 [ 3612 ] {d860595f-a9c1-4e0d-82bc-41615a04cdaf} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:59.072001 [ 3722 ] {ed94c5cd-4d83-431d-be4b-75db9a3ce447} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:58162) (comment: 01542_dictionary_load_exception_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:59.078391 [ 3722 ] {ed94c5cd-4d83-431d-be4b-75db9a3ce447} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:59.118667 [ 20849 ] {1353f60d-d3d5-4659-8455-cbe023c32591} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:58178) (comment: 01542_dictionary_load_exception_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:59.136072 [ 20849 ] {1353f60d-d3d5-4659-8455-cbe023c32591} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:59.335025 [ 2688 ] {80e20584-7a50-4c5c-963f-a51e8fbf8ef2} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:58192) (comment: 01542_dictionary_load_exception_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:59.346401 [ 2688 ] {80e20584-7a50-4c5c-963f-a51e8fbf8ef2} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:59.409686 [ 20884 ] {8b204534-bcda-4f5e-8518-1efe703e27be} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:58210) (comment: 01542_dictionary_load_exception_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:59.422528 [ 20884 ] {8b204534-bcda-4f5e-8518-1efe703e27be} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:59.438395 [ 20882 ] {a5368327-a425-4878-bdfa-ff03c528fec9} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:58234) (comment: 01542_dictionary_load_exception_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:59.442351 [ 3612 ] {e27fb3d1-a2c6-4130-a6e0-9ba494a21090} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:58224) (comment: 01542_dictionary_load_exception_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:59.446429 [ 20882 ] {a5368327-a425-4878-bdfa-ff03c528fec9} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:59.458214 [ 3612 ] {e27fb3d1-a2c6-4130-a6e0-9ba494a21090} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:59.469797 [ 20355 ] {20b45bf8-6d37-48c5-8ef9-1d8dbf03ecd0} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:58198) (comment: 01542_dictionary_load_exception_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:59.477054 [ 20355 ] {20b45bf8-6d37-48c5-8ef9-1d8dbf03ecd0} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:59.489133 [ 2879 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:07:59.543987 [ 20881 ] {f97d94c3-f32a-40be-9f89-f31c9014bca6} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:58226) (comment: 01542_dictionary_load_exception_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:59.554437 [ 20881 ] {f97d94c3-f32a-40be-9f89-f31c9014bca6} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:59.804290 [ 20355 ] {1255ed7e-2ef7-40a7-a991-3a2629458888} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:58250) (comment: 01542_dictionary_load_exception_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:59.804234 [ 20345 ] {de14961a-1b63-4a10-bdd2-8b4ef013889c} executeQuery: Code: 42. DB::Exception: Number of arguments for function clamp doesn't match: passed 2, should be 3: In scope SELECT clamp(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT clamp(NULL, NULL);) 2025.09.09 15:07:59.810571 [ 20355 ] {1255ed7e-2ef7-40a7-a991-3a2629458888} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:59.834531 [ 20345 ] {de14961a-1b63-4a10-bdd2-8b4ef013889c} TCPHandler: Code: 42. DB::Exception: Number of arguments for function clamp doesn't match: passed 2, should be 3: In scope SELECT clamp(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:07:59.848181 [ 20882 ] {558e6448-6465-427c-a765-8afcffd6dd41} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:58272) (comment: 01542_dictionary_load_exception_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:59.848771 [ 2994 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:07:59.850541 [ 20882 ] {558e6448-6465-427c-a765-8afcffd6dd41} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:59.863926 [ 2969 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:07:59.864406 [ 2980 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:07:59.870930 [ 3612 ] {64f0c762-8eec-4e99-afe2-e12b9b5ca574} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:58266) (comment: 01542_dictionary_load_exception_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:59.873084 [ 3612 ] {64f0c762-8eec-4e99-afe2-e12b9b5ca574} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:59.879293 [ 20884 ] {6cd417da-9097-4fd6-b92d-2823abf7a7ab} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:58262) (comment: 01542_dictionary_load_exception_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:59.881469 [ 20884 ] {6cd417da-9097-4fd6-b92d-2823abf7a7ab} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:59.893771 [ 20881 ] {36dc7d6c-b8f4-44ad-88db-89e44e263a41} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:58284) (comment: 01542_dictionary_load_exception_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:59.895881 [ 20881 ] {36dc7d6c-b8f4-44ad-88db-89e44e263a41} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:07:59.974271 [ 20338 ] {3b923fd1-844d-4b61-9192-12a2a00ae1a5} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:58294) (comment: 01542_dictionary_load_exception_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:08:00.015769 [ 20338 ] {3b923fd1-844d-4b61-9192-12a2a00ae1a5} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:08:00.210872 [ 20884 ] {8180aafc-0c89-4fd9-8d69-54eab170adcf} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:58310) (comment: 01542_dictionary_load_exception_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:08:00.218641 [ 20884 ] {8180aafc-0c89-4fd9-8d69-54eab170adcf} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:08:00.265929 [ 3612 ] {e4625159-d6ad-49bd-8411-cd5a048f8a92} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:58324) (comment: 01542_dictionary_load_exception_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:08:00.271718 [ 3612 ] {e4625159-d6ad-49bd-8411-cd5a048f8a92} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:08:00.312208 [ 20355 ] {024409e8-018e-423c-9852-fef036f9ef9b} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:58304) (comment: 01542_dictionary_load_exception_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:08:00.330462 [ 20355 ] {024409e8-018e-423c-9852-fef036f9ef9b} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:08:00.334420 [ 20882 ] {392c3021-27c8-48de-b688-47e504be8d88} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:58338) (comment: 01542_dictionary_load_exception_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:08:00.342535 [ 20882 ] {392c3021-27c8-48de-b688-47e504be8d88} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:08:00.367795 [ 20881 ] {de58bd63-048c-4699-b91d-e8090cdca541} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:58336) (comment: 01542_dictionary_load_exception_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:08:00.394290 [ 20881 ] {de58bd63-048c-4699-b91d-e8090cdca541} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:08:00.491309 [ 3038 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:08:00.599264 [ 20338 ] {dec9fcb2-e51f-46b6-b755-2475550d1142} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:58340) (comment: 01542_dictionary_load_exception_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:08:00.606441 [ 20338 ] {dec9fcb2-e51f-46b6-b755-2475550d1142} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:08:00.761941 [ 20884 ] {d20a4f05-e53f-4acf-8213-49cafba0318f} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:58346) (comment: 01542_dictionary_load_exception_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:08:00.763811 [ 20884 ] {d20a4f05-e53f-4acf-8213-49cafba0318f} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:08:00.770246 [ 20355 ] {004d7a51-a33d-4684-a037-6c94fd560a65} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:58352) (comment: 01542_dictionary_load_exception_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:08:00.772020 [ 20355 ] {004d7a51-a33d-4684-a037-6c94fd560a65} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:08:00.819808 [ 20882 ] {c5d80daa-6ad5-4955-bb6d-1e53b083a5c9} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:58354) (comment: 01542_dictionary_load_exception_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:08:00.821551 [ 20882 ] {c5d80daa-6ad5-4955-bb6d-1e53b083a5c9} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:08:00.827157 [ 20353 ] {76930eb7-5133-46a4-b159-20f9accc2d0d} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:58386) (comment: 01542_dictionary_load_exception_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:08:00.838887 [ 20353 ] {76930eb7-5133-46a4-b159-20f9accc2d0d} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:08:00.847468 [ 20881 ] {7d240b94-d695-4a50-96fd-88ab81eb911e} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:58376) (comment: 01542_dictionary_load_exception_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:08:00.847874 [ 3612 ] {dfa7045d-8e21-4ebd-87af-09b049524070} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:58370) (comment: 01542_dictionary_load_exception_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:08:00.854703 [ 3049 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:08:00.854886 [ 20881 ] {7d240b94-d695-4a50-96fd-88ab81eb911e} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:08:00.854641 [ 3612 ] {dfa7045d-8e21-4ebd-87af-09b049524070} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:08:00.866863 [ 3074 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:08:00.868085 [ 3072 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:08:01.051639 [ 20351 ] {b60c4644-5c98-41df-ab5a-41878084dcb0} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:58404) (comment: 01542_dictionary_load_exception_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:08:01.057817 [ 20351 ] {b60c4644-5c98-41df-ab5a-41878084dcb0} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:08:01.093858 [ 20355 ] {b45f8316-b58f-427f-8d2f-34eae1609c1e} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:58414) (comment: 01542_dictionary_load_exception_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:08:01.095542 [ 20338 ] {0592f3a7-2441-4c6d-b3e2-a14f0495e20c} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:58400) (comment: 01542_dictionary_load_exception_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:08:01.095802 [ 20355 ] {b45f8316-b58f-427f-8d2f-34eae1609c1e} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:08:01.111543 [ 20338 ] {0592f3a7-2441-4c6d-b3e2-a14f0495e20c} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:08:01.179024 [ 20881 ] {c26fe466-43bc-49ca-8db0-95f082e789f4} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(equals(__table1.dummy, 0_UInt8) :: 0) -> throwIf(equals(__table1.dummy, 0_UInt8)) UInt8 : 1'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10505.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:57366) (comment: 01752_distributed_query_sigsegv.sql) (in query: SELECT throwIf(`__table1`.`dummy` = 0) AS `throwIf(equals(dummy, 0))` FROM `system`.`one` AS `__table1`), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000aad4b34 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001859ee9c 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aac9135 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000cccce5b 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccce65c 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd2030 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x00000000286fc2bd 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000002d9c29ae 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000002d34877c 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000002d34827b 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*) @ 0x000000002d36bcf7 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 20. asan_thread_start(void*) @ 0x000000000aa43059 21. ? @ 0x00007f35aab92ac3 22. ? @ 0x00007f35aac24850 2025.09.09 15:08:01.189783 [ 20881 ] {c26fe466-43bc-49ca-8db0-95f082e789f4} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(equals(__table1.dummy, 0_UInt8) :: 0) -> throwIf(equals(__table1.dummy, 0_UInt8)) UInt8 : 1'. (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000aad4b34 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001859ee9c 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aac9135 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000cccce5b 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccce65c 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd2030 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x00000000286fc2bd 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000002d9c29ae 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000002d34877c 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000002d34827b 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*) @ 0x000000002d36bcf7 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 20. asan_thread_start(void*) @ 0x000000000aa43059 21. ? @ 0x00007f35aab92ac3 22. ? @ 0x00007f35aac24850 2025.09.09 15:08:01.192359 [ 20345 ] {702e3a66-e9b6-4f94-a1cd-f6f9499a9ae4} executeQuery: Code: 42. DB::Exception: Number of arguments for function connectionId doesn't match: passed 2, should be 0: In scope SELECT connectionId(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT connectionId(NULL, NULL);) 2025.09.09 15:08:01.195441 [ 3612 ] {4a48fc3a-301c-48c1-baba-67037dd2cc9d} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:58432) (comment: 01542_dictionary_load_exception_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:08:01.206634 [ 3612 ] {4a48fc3a-301c-48c1-baba-67037dd2cc9d} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:08:01.213198 [ 20345 ] {702e3a66-e9b6-4f94-a1cd-f6f9499a9ae4} TCPHandler: Code: 42. DB::Exception: Number of arguments for function connectionId doesn't match: passed 2, should be 0: In scope SELECT connectionId(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:08:01.215746 [ 20350 ] {6cc31b6f-642c-47ba-ad8a-9c6a8165b57a} executeQuery: Code: 395. DB::Exception: Received from 127.1:9000. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(equals(__table1.dummy, 0_UInt8) :: 0) -> throwIf(equals(__table1.dummy, 0_UInt8)) UInt8 : 1'. Stack trace: 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000aad4b34 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001859ee9c 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aac9135 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000cccce5b 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccce65c 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd2030 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x00000000286fc2bd 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000002d9c29ae 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000002d34877c 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000002d34827b 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*) @ 0x000000002d36bcf7 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 20. asan_thread_start(void*) @ 0x000000000aa43059 21. ? @ 0x00007f35aab92ac3 22. ? @ 0x00007f35aac24850 : While executing Remote. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:58392) (comment: 01752_distributed_query_sigsegv.sql) (in query: -- this is enough to trigger the regression SELECT throwIf(dummy = 0) FROM remote('127.1', system.one);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. ./contrib/llvm-project/libcxx/include/string:1499: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x000000001aeb974e 3. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::Connection::receiveException() const @ 0x000000002cee6c6a 4. ./build_docker/./src/Client/Connection.cpp:0: DB::Connection::receivePacket() @ 0x000000002cef780e 5. ./build_docker/./src/Client/PacketReceiver.cpp:0: DB::PacketReceiver::Task::run(std::function, std::function) @ 0x000000002cf9767e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000278ab436 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000278aaa44 8. ./contrib/boost/boost/context/fiber_ucontext.hpp:82: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x00000000278a8394 2025.09.09 15:08:01.220090 [ 20350 ] {6cc31b6f-642c-47ba-ad8a-9c6a8165b57a} TCPHandler: Code: 395. DB::Exception: Received from 127.1:9000. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(equals(__table1.dummy, 0_UInt8) :: 0) -> throwIf(equals(__table1.dummy, 0_UInt8)) UInt8 : 1'. Stack trace: 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000aad4b34 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001859ee9c 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aac9135 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000cccce5b 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccce65c 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd2030 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x00000000286fc2bd 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000002d9c29ae 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000002d34877c 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000002d34827b 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*) @ 0x000000002d36bcf7 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 20. asan_thread_start(void*) @ 0x000000000aa43059 21. ? @ 0x00007f35aab92ac3 22. ? @ 0x00007f35aac24850 : 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. ./contrib/llvm-project/libcxx/include/string:1499: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x000000001aeb974e 3. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::Connection::receiveException() const @ 0x000000002cee6c6a 4. ./build_docker/./src/Client/Connection.cpp:0: DB::Connection::receivePacket() @ 0x000000002cef780e 5. ./build_docker/./src/Client/PacketReceiver.cpp:0: DB::PacketReceiver::Task::run(std::function, std::function) @ 0x000000002cf9767e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000278ab436 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000278aaa44 8. ./contrib/boost/boost/context/fiber_ucontext.hpp:82: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x00000000278a8394 2025.09.09 15:08:01.277175 [ 20884 ] {4d0a0de9-2f4f-467f-8e08-6ce52ed7445f} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:58426) (comment: 01542_dictionary_load_exception_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:08:01.291577 [ 20884 ] {4d0a0de9-2f4f-467f-8e08-6ce52ed7445f} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:08:01.300144 [ 20345 ] {818dc264-c0f6-40bc-b7e1-0db4e0af8aa9} executeQuery: Code: 42. DB::Exception: Number of arguments for function connectionId doesn't match: passed 2, should be 0: In scope SELECT connection_id(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT connection_id(NULL, NULL);) 2025.09.09 15:08:01.304005 [ 20345 ] {818dc264-c0f6-40bc-b7e1-0db4e0af8aa9} TCPHandler: Code: 42. DB::Exception: Number of arguments for function connectionId doesn't match: passed 2, should be 0: In scope SELECT connection_id(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:08:01.348874 [ 20884 ] {} ServerErrorHandler: Code: 210. DB::NetException: Connection reset by peer, while reading from socket (peer: [::1]:58426, 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 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&&) @ 0x000000001b0b7a5f 3. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:83: DB::ReadBufferFromPocoSocketBase::socketReceiveBytesImpl(char*, unsigned long) @ 0x000000001b0b6042 4. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:107: DB::ReadBufferFromPocoSocketBase::nextImpl() @ 0x000000001b0b6b84 5. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:103: DB::ReadBufferFromPocoSocketChunked::nextImpl() @ 0x000000002cf045f6 6. DB::ReadBuffer::next() @ 0x000000000b528aeb 7. ./build_docker/./src/Server/TCPHandler.cpp:383: DB::TCPHandler::runImpl() @ 0x000000002d174fd3 8. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 12. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 13. asan_thread_start(void*) @ 0x000000000aa43059 14. ? @ 0x00007f35aab92ac3 15. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:08:01.443430 [ 20355 ] {a94874da-87c0-421e-91a8-ca1faa7e43a4} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:58444) (comment: 01542_dictionary_load_exception_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:08:01.446079 [ 20355 ] {a94874da-87c0-421e-91a8-ca1faa7e43a4} TCPHandler: Can't send logs to client: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::1]:9000 -> [::1]:58444). (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 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&&) @ 0x000000001b0b7a5f 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:169: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000001b0bada2 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:201: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000002cf09bf7 5. ./src/IO/WriteBuffer.h:66: DB::TCPHandler::sendLogData(DB::Block const&) @ 0x000000002d1a9beb 6. ./contrib/llvm-project/libcxx/include/__hash_table:1473: DB::TCPHandler::sendLogs() @ 0x000000002d18db59 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d176902 8. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 12. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 13. asan_thread_start(void*) @ 0x000000000aa43059 14. ? @ 0x00007f35aab92ac3 15. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:08:01.448427 [ 20355 ] {a94874da-87c0-421e-91a8-ca1faa7e43a4} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:08:01.450453 [ 20355 ] {a94874da-87c0-421e-91a8-ca1faa7e43a4} TCPHandler: Client has gone away. 2025.09.09 15:08:01.466094 [ 3612 ] {9e9480a6-e71e-44a8-a1cf-97b021fee86b} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (TOO_MANY_ROWS_OR_BYTES) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:58458) (comment: 01542_dictionary_load_exception_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:08:01.467886 [ 20338 ] {ed9a6346-839c-445e-92b0-492aa487f21f} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(equals(__table1.dummy, 0_UInt8) :: 0) -> throwIf(equals(__table1.dummy, 0_UInt8)) UInt8 : 1'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10505.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:40692) (comment: 01752_distributed_query_sigsegv.sql) (in query: SELECT throwIf(`__table1`.`dummy` = 0) AS `throwIf(equals(dummy, 0))` FROM `system`.`one` AS `__table1`), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000aad4b34 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001859ee9c 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aac9135 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000cccce5b 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccce65c 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd2030 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x00000000286fc2bd 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000002d9c29ae 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000002d34877c 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000002d34827b 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*) @ 0x000000002d36bcf7 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 20. asan_thread_start(void*) @ 0x000000000aa43059 21. ? @ 0x00007f35aab92ac3 22. ? @ 0x00007f35aac24850 2025.09.09 15:08:01.469825 [ 3612 ] {9e9480a6-e71e-44a8-a1cf-97b021fee86b} TCPHandler: Can't send logs to client: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::1]:9000 -> [::1]:58458). (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 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&&) @ 0x000000001b0b7a5f 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:169: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000001b0bada2 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:201: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000002cf09bf7 5. ./src/IO/WriteBuffer.h:66: DB::TCPHandler::sendLogData(DB::Block const&) @ 0x000000002d1a9beb 6. ./contrib/llvm-project/libcxx/include/__hash_table:1473: DB::TCPHandler::sendLogs() @ 0x000000002d18db59 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d176902 8. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 12. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 13. asan_thread_start(void*) @ 0x000000000aa43059 14. ? @ 0x00007f35aab92ac3 15. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:08:01.470208 [ 20338 ] {ed9a6346-839c-445e-92b0-492aa487f21f} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(equals(__table1.dummy, 0_UInt8) :: 0) -> throwIf(equals(__table1.dummy, 0_UInt8)) UInt8 : 1'. (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000aad4b34 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001859ee9c 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aac9135 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000cccce5b 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccce65c 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd2030 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x00000000286fc2bd 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000002d9c29ae 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000002d34877c 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000002d34827b 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*) @ 0x000000002d36bcf7 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 20. asan_thread_start(void*) @ 0x000000000aa43059 21. ? @ 0x00007f35aab92ac3 22. ? @ 0x00007f35aac24850 2025.09.09 15:08:01.471761 [ 3612 ] {9e9480a6-e71e-44a8-a1cf-97b021fee86b} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000278b3740 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b318c 5. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000002d9e7dde 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d349032 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d36e196 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d36e6f6 13. DB::FlatDictionary::loadData() @ 0x000000001b6725cb 14. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67186a 15. 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) @ 0x000000001b6b9545 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 17. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 19. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:08:01.477722 [ 20882 ] {84ad7776-ddbe-4cab-bb04-036cdc21fa28} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(equals(__table1.dummy, 0_UInt8) :: 0) -> throwIf(equals(__table1.dummy, 0_UInt8)) UInt8 : 1'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10505.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:57376) (comment: 01752_distributed_query_sigsegv.sql) (in query: SELECT throwIf(`__table1`.`dummy` = 0) AS `throwIf(equals(dummy, 0))` FROM `system`.`one` AS `__table1`), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000aad4b34 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001859ee9c 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aac9135 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000cccce5b 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccce65c 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd2030 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x00000000286fc2bd 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000002d9c29ae 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000002d34877c 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000002d34827b 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*) @ 0x000000002d36bcf7 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 20. asan_thread_start(void*) @ 0x000000000aa43059 21. ? @ 0x00007f35aab92ac3 22. ? @ 0x00007f35aac24850 2025.09.09 15:08:01.480410 [ 20882 ] {84ad7776-ddbe-4cab-bb04-036cdc21fa28} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(equals(__table1.dummy, 0_UInt8) :: 0) -> throwIf(equals(__table1.dummy, 0_UInt8)) UInt8 : 1'. (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000aad4b34 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001859ee9c 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aac9135 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000cccce5b 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccce65c 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd2030 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x00000000286fc2bd 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000002d9c29ae 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000002d34877c 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000002d34827b 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*) @ 0x000000002d36bcf7 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 20. asan_thread_start(void*) @ 0x000000000aa43059 21. ? @ 0x00007f35aab92ac3 22. ? @ 0x00007f35aac24850 2025.09.09 15:08:01.482647 [ 3612 ] {9e9480a6-e71e-44a8-a1cf-97b021fee86b} TCPHandler: Client has gone away. 2025.09.09 15:08:01.485126 [ 20345 ] {cdd8968e-1987-4fb5-bd0a-859977fa2b0e} executeQuery: Code: 42. DB::Exception: Number of arguments for function convertCharset doesn't match: passed 2, should be 3: In scope SELECT convertCharset(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT convertCharset(NULL, NULL);) 2025.09.09 15:08:01.488855 [ 20345 ] {cdd8968e-1987-4fb5-bd0a-859977fa2b0e} TCPHandler: Code: 42. DB::Exception: Number of arguments for function convertCharset doesn't match: passed 2, should be 3: In scope SELECT convertCharset(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:08:01.491657 [ 20350 ] {b6856f0a-0dbf-4ade-81d3-f351d282ceee} executeQuery: Code: 395. DB::Exception: Received from 127.2:9000. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(equals(__table1.dummy, 0_UInt8) :: 0) -> throwIf(equals(__table1.dummy, 0_UInt8)) UInt8 : 1'. Stack trace: 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000aad4b34 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001859ee9c 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aac9135 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000cccce5b 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccce65c 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd2030 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x00000000286fc2bd 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000002d9c29ae 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000002d34877c 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000002d34827b 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*) @ 0x000000002d36bcf7 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 20. asan_thread_start(void*) @ 0x000000000aa43059 21. ? @ 0x00007f35aab92ac3 22. ? @ 0x00007f35aac24850 : While executing Remote. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:58392) (comment: 01752_distributed_query_sigsegv.sql) (in query: -- these are just in case SELECT throwIf(dummy = 0) FROM remote('127.{1,2}', system.one);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. ./contrib/llvm-project/libcxx/include/string:1499: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x000000001aeb974e 3. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::Connection::receiveException() const @ 0x000000002cee6c6a 4. ./build_docker/./src/Client/Connection.cpp:0: DB::Connection::receivePacket() @ 0x000000002cef780e 5. ./build_docker/./src/Client/PacketReceiver.cpp:0: DB::PacketReceiver::Task::run(std::function, std::function) @ 0x000000002cf9767e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000278ab436 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000278aaa44 8. ./contrib/boost/boost/context/fiber_ucontext.hpp:82: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x00000000278a8394 2025.09.09 15:08:01.493285 [ 3132 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:08:01.494811 [ 20350 ] {b6856f0a-0dbf-4ade-81d3-f351d282ceee} TCPHandler: Code: 395. DB::Exception: Received from 127.2:9000. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(equals(__table1.dummy, 0_UInt8) :: 0) -> throwIf(equals(__table1.dummy, 0_UInt8)) UInt8 : 1'. Stack trace: 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000aad4b34 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001859ee9c 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aac9135 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000cccce5b 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccce65c 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd2030 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x00000000286fc2bd 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000002d9c29ae 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000002d34877c 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000002d34827b 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*) @ 0x000000002d36bcf7 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 20. asan_thread_start(void*) @ 0x000000000aa43059 21. ? @ 0x00007f35aab92ac3 22. ? @ 0x00007f35aac24850 : 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. ./contrib/llvm-project/libcxx/include/string:1499: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x000000001aeb974e 3. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::Connection::receiveException() const @ 0x000000002cee6c6a 4. ./build_docker/./src/Client/Connection.cpp:0: DB::Connection::receivePacket() @ 0x000000002cef780e 5. ./build_docker/./src/Client/PacketReceiver.cpp:0: DB::PacketReceiver::Task::run(std::function, std::function) @ 0x000000002cf9767e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000278ab436 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000278aaa44 8. ./contrib/boost/boost/context/fiber_ucontext.hpp:82: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x00000000278a8394 2025.09.09 15:08:01.758620 [ 20882 ] {030b3344-80d0-4bfe-bb5e-8c50a62c49cb} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(equals(__table1.dummy, 0_UInt8) :: 0) -> throwIf(equals(__table1.dummy, 0_UInt8)) UInt8 : 1'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10505.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:40702) (comment: 01752_distributed_query_sigsegv.sql) (in query: SELECT throwIf(`__table1`.`dummy` = 0) AS `throwIf(equals(dummy, 0))` FROM `system`.`one` AS `__table1`), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000aad4b34 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001859ee9c 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aac9135 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000cccce5b 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccce65c 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd2030 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x00000000286fc2bd 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000002d9c29ae 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000002d34877c 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000002d34827b 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*) @ 0x000000002d36bcf7 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 20. asan_thread_start(void*) @ 0x000000000aa43059 21. ? @ 0x00007f35aab92ac3 22. ? @ 0x00007f35aac24850 2025.09.09 15:08:01.771387 [ 20882 ] {030b3344-80d0-4bfe-bb5e-8c50a62c49cb} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(equals(__table1.dummy, 0_UInt8) :: 0) -> throwIf(equals(__table1.dummy, 0_UInt8)) UInt8 : 1'. (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000aad4b34 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001859ee9c 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aac9135 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000cccce5b 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccce65c 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd2030 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x00000000286fc2bd 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000002d9c29ae 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000002d34877c 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000002d34827b 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*) @ 0x000000002d36bcf7 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 20. asan_thread_start(void*) @ 0x000000000aa43059 21. ? @ 0x00007f35aab92ac3 22. ? @ 0x00007f35aac24850 2025.09.09 15:08:01.860747 [ 3149 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:08:01.869652 [ 3177 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:08:01.873005 [ 3162 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:08:01.887911 [ 20350 ] {f7e81592-4e9b-4b33-8ec3-3298d36feb4d} executeQuery: Code: 395. DB::Exception: Received from 127.2:9000. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(equals(__table1.dummy, 0_UInt8) :: 0) -> throwIf(equals(__table1.dummy, 0_UInt8)) UInt8 : 1'. Stack trace: 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000aad4b34 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001859ee9c 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aac9135 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000cccce5b 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccce65c 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd2030 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x00000000286fc2bd 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000002d9c29ae 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000002d34877c 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000002d34827b 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*) @ 0x000000002d36bcf7 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 20. asan_thread_start(void*) @ 0x000000000aa43059 21. ? @ 0x00007f35aab92ac3 22. ? @ 0x00007f35aac24850 : While executing Remote. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:58392) (comment: 01752_distributed_query_sigsegv.sql) (in query: SELECT throwIf(dummy = 0) FROM remote('127.{1,2}', system.one) SETTINGS prefer_localhost_replica=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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. ./contrib/llvm-project/libcxx/include/string:1499: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x000000001aeb974e 3. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::Connection::receiveException() const @ 0x000000002cee6c6a 4. ./build_docker/./src/Client/Connection.cpp:0: DB::Connection::receivePacket() @ 0x000000002cef780e 5. ./build_docker/./src/Client/PacketReceiver.cpp:0: DB::PacketReceiver::Task::run(std::function, std::function) @ 0x000000002cf9767e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000278ab436 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000278aaa44 8. ./contrib/boost/boost/context/fiber_ucontext.hpp:82: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x00000000278a8394 2025.09.09 15:08:01.888806 [ 20881 ] {43c7d983-319d-40f3-bc3d-cb726b80d47c} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(equals(__table1.dummy, 0_UInt8) :: 0) -> throwIf(equals(__table1.dummy, 0_UInt8)) UInt8 : 1'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10505.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:57386) (comment: 01752_distributed_query_sigsegv.sql) (in query: SELECT throwIf(`__table1`.`dummy` = 0) AS `throwIf(equals(dummy, 0))` FROM `system`.`one` AS `__table1`), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000aad4b34 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001859ee9c 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aac9135 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000cccce5b 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccce65c 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd2030 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x00000000286fc2bd 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000002d9c29ae 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000002d34877c 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000002d34827b 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*) @ 0x000000002d36bcf7 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 20. asan_thread_start(void*) @ 0x000000000aa43059 21. ? @ 0x00007f35aab92ac3 22. ? @ 0x00007f35aac24850 2025.09.09 15:08:01.889877 [ 20881 ] {43c7d983-319d-40f3-bc3d-cb726b80d47c} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(equals(__table1.dummy, 0_UInt8) :: 0) -> throwIf(equals(__table1.dummy, 0_UInt8)) UInt8 : 1'. (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000aad4b34 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001859ee9c 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aac9135 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000cccce5b 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccce65c 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd2030 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x00000000286fc2bd 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000002d9c29ae 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000002d34877c 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000002d34827b 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*) @ 0x000000002d36bcf7 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 20. asan_thread_start(void*) @ 0x000000000aa43059 21. ? @ 0x00007f35aab92ac3 22. ? @ 0x00007f35aac24850 2025.09.09 15:08:01.890979 [ 20350 ] {f7e81592-4e9b-4b33-8ec3-3298d36feb4d} TCPHandler: Code: 395. DB::Exception: Received from 127.2:9000. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(equals(__table1.dummy, 0_UInt8) :: 0) -> throwIf(equals(__table1.dummy, 0_UInt8)) UInt8 : 1'. Stack trace: 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000aad4b34 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001859ee9c 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aac9135 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000cccce5b 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccce65c 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd2030 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x00000000286fc2bd 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000002d9c29ae 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000002d34877c 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000002d34827b 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*) @ 0x000000002d36bcf7 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 20. asan_thread_start(void*) @ 0x000000000aa43059 21. ? @ 0x00007f35aab92ac3 22. ? @ 0x00007f35aac24850 : 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. ./contrib/llvm-project/libcxx/include/string:1499: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x000000001aeb974e 3. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::Connection::receiveException() const @ 0x000000002cee6c6a 4. ./build_docker/./src/Client/Connection.cpp:0: DB::Connection::receivePacket() @ 0x000000002cef780e 5. ./build_docker/./src/Client/PacketReceiver.cpp:0: DB::PacketReceiver::Task::run(std::function, std::function) @ 0x000000002cf9767e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000278ab436 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000278aaa44 8. ./contrib/boost/boost/context/fiber_ucontext.hpp:82: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x00000000278a8394 2025.09.09 15:08:01.929005 [ 20345 ] {458315c6-5294-4521-b55f-d4d110ebe76e} executeQuery: Code: 42. DB::Exception: Number of arguments for function cos doesn't match: passed 2, should be 1: In scope SELECT cos(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT cos(NULL, NULL);) 2025.09.09 15:08:01.935028 [ 20345 ] {458315c6-5294-4521-b55f-d4d110ebe76e} TCPHandler: Code: 42. DB::Exception: Number of arguments for function cos doesn't match: passed 2, should be 1: In scope SELECT cos(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:08:02.002710 [ 20345 ] {c4330efe-5391-4948-b655-045f30202de3} executeQuery: Code: 42. DB::Exception: Number of arguments for function cosh doesn't match: passed 2, should be 1: In scope SELECT cosh(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT cosh(NULL, NULL);) 2025.09.09 15:08:02.007184 [ 20345 ] {c4330efe-5391-4948-b655-045f30202de3} TCPHandler: Code: 42. DB::Exception: Number of arguments for function cosh doesn't match: passed 2, should be 1: In scope SELECT cosh(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:08:02.167526 [ 20881 ] {dd2ac79c-4c08-47bb-b306-356ccd584392} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(equals(__table1.dummy, 0_UInt8) :: 0) -> throwIf(equals(__table1.dummy, 0_UInt8)) UInt8 : 1'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10505.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:57394) (comment: 01752_distributed_query_sigsegv.sql) (in query: SELECT throwIf(`__table1`.`dummy` = 0) AS `throwIf(equals(dummy, 0))` FROM `system`.`one` AS `__table1`), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000aad4b34 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001859ee9c 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aac9135 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000cccce5b 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccce65c 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd2030 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x00000000286fc2bd 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000002d9c29ae 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000002d34877c 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000002d34827b 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*) @ 0x000000002d36bcf7 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 20. asan_thread_start(void*) @ 0x000000000aa43059 21. ? @ 0x00007f35aab92ac3 22. ? @ 0x00007f35aac24850 2025.09.09 15:08:02.169417 [ 20881 ] {dd2ac79c-4c08-47bb-b306-356ccd584392} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(equals(__table1.dummy, 0_UInt8) :: 0) -> throwIf(equals(__table1.dummy, 0_UInt8)) UInt8 : 1'. (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000aad4b34 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001859ee9c 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aac9135 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000cccce5b 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccce65c 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd2030 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x00000000286fc2bd 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000002d9c29ae 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000002d34877c 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000002d34827b 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*) @ 0x000000002d36bcf7 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 20. asan_thread_start(void*) @ 0x000000000aa43059 21. ? @ 0x00007f35aab92ac3 22. ? @ 0x00007f35aac24850 2025.09.09 15:08:02.178122 [ 20882 ] {26c02cfe-8294-4e23-b9a6-b675c78306ef} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(equals(__table1.dummy, 0_UInt8) :: 0) -> throwIf(equals(__table1.dummy, 0_UInt8)) UInt8 : 1'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10505.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:40712) (comment: 01752_distributed_query_sigsegv.sql) (in query: SELECT throwIf(`__table1`.`dummy` = 0) AS `throwIf(equals(dummy, 0))` FROM `system`.`one` AS `__table1`), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000aad4b34 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001859ee9c 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aac9135 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000cccce5b 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccce65c 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd2030 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x00000000286fc2bd 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000002d9c29ae 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000002d34877c 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000002d34827b 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*) @ 0x000000002d36bcf7 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 20. asan_thread_start(void*) @ 0x000000000aa43059 21. ? @ 0x00007f35aab92ac3 22. ? @ 0x00007f35aac24850 2025.09.09 15:08:02.179339 [ 20882 ] {26c02cfe-8294-4e23-b9a6-b675c78306ef} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(equals(__table1.dummy, 0_UInt8) :: 0) -> throwIf(equals(__table1.dummy, 0_UInt8)) UInt8 : 1'. (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000aad4b34 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001859ee9c 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aac9135 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000cccce5b 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccce65c 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd2030 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x00000000286fc2bd 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000002d9c29ae 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000002d34877c 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000002d34827b 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*) @ 0x000000002d36bcf7 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 20. asan_thread_start(void*) @ 0x000000000aa43059 21. ? @ 0x00007f35aab92ac3 22. ? @ 0x00007f35aac24850 2025.09.09 15:08:02.185604 [ 20350 ] {fa9a08e4-3b41-4f94-8c44-1c44cccb2c4d} executeQuery: Code: 395. DB::Exception: Received from 127.1:9000. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(equals(__table1.dummy, 0_UInt8) :: 0) -> throwIf(equals(__table1.dummy, 0_UInt8)) UInt8 : 1'. Stack trace: 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000aad4b34 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001859ee9c 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aac9135 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000cccce5b 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccce65c 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd2030 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x00000000286fc2bd 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000002d9c29ae 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000002d34877c 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000002d34827b 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*) @ 0x000000002d36bcf7 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 20. asan_thread_start(void*) @ 0x000000000aa43059 21. ? @ 0x00007f35aab92ac3 22. ? @ 0x00007f35aac24850 : While executing Remote. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:58392) (comment: 01752_distributed_query_sigsegv.sql) (in query: SELECT throwIf(dummy = 0) FROM remote('127.{1,2}', system.one) SETTINGS prefer_localhost_replica=0, distributed_group_by_no_merge=1;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. ./contrib/llvm-project/libcxx/include/string:1499: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x000000001aeb974e 3. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::Connection::receiveException() const @ 0x000000002cee6c6a 4. ./build_docker/./src/Client/Connection.cpp:0: DB::Connection::receivePacket() @ 0x000000002cef780e 5. ./build_docker/./src/Client/PacketReceiver.cpp:0: DB::PacketReceiver::Task::run(std::function, std::function) @ 0x000000002cf9767e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000278ab436 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000278aaa44 8. ./contrib/boost/boost/context/fiber_ucontext.hpp:82: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x00000000278a8394 2025.09.09 15:08:02.187567 [ 20350 ] {fa9a08e4-3b41-4f94-8c44-1c44cccb2c4d} TCPHandler: Code: 395. DB::Exception: Received from 127.1:9000. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(equals(__table1.dummy, 0_UInt8) :: 0) -> throwIf(equals(__table1.dummy, 0_UInt8)) UInt8 : 1'. Stack trace: 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000aad4b34 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001859ee9c 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aac9135 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000cccce5b 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccce65c 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd2030 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x00000000286fc2bd 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000002d9c29ae 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000002d34877c 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000002d34827b 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*) @ 0x000000002d36bcf7 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 20. asan_thread_start(void*) @ 0x000000000aa43059 21. ? @ 0x00007f35aab92ac3 22. ? @ 0x00007f35aac24850 : 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. ./contrib/llvm-project/libcxx/include/string:1499: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x000000001aeb974e 3. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::Connection::receiveException() const @ 0x000000002cee6c6a 4. ./build_docker/./src/Client/Connection.cpp:0: DB::Connection::receivePacket() @ 0x000000002cef780e 5. ./build_docker/./src/Client/PacketReceiver.cpp:0: DB::PacketReceiver::Task::run(std::function, std::function) @ 0x000000002cf9767e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000278ab436 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000278aaa44 8. ./contrib/boost/boost/context/fiber_ucontext.hpp:82: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x00000000278a8394 2025.09.09 15:08:02.217547 [ 20345 ] {441cd934-c7e5-4095-b0fd-84fb9626d5b7} executeQuery: Code: 42. DB::Exception: Aggregate function count requires zero or one argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT count(NULL, NULL);) 2025.09.09 15:08:02.222118 [ 20345 ] {441cd934-c7e5-4095-b0fd-84fb9626d5b7} TCPHandler: Code: 42. DB::Exception: Aggregate function count requires zero or one argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:08:02.279587 [ 20345 ] {5059c803-f4d8-4e67-9aac-853e7df5aaf3} executeQuery: Code: 42. DB::Exception: Number of arguments for function countDigits doesn't match: passed 2, should be 1: In scope SELECT countDigits(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT countDigits(NULL, NULL);) 2025.09.09 15:08:02.283251 [ 20345 ] {5059c803-f4d8-4e67-9aac-853e7df5aaf3} TCPHandler: Code: 42. DB::Exception: Number of arguments for function countDigits doesn't match: passed 2, should be 1: In scope SELECT countDigits(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:08:02.386496 [ 20881 ] {bc73bb13-4dae-44e5-9624-5d170bafaf0c} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(equals(__table1.dummy, 0_UInt8) :: 0) -> throwIf(equals(__table1.dummy, 0_UInt8)) UInt8 : 1'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10505.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:57408) (comment: 01752_distributed_query_sigsegv.sql) (in query: SELECT throwIf(`__table1`.`dummy` = 0) AS `throwIf(equals(dummy, 0))` FROM `system`.`one` AS `__table1`), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000aad4b34 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001859ee9c 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aac9135 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000cccce5b 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccce65c 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd2030 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x00000000286fc2bd 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000002d9c29ae 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000002d34877c 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000002d34827b 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*) @ 0x000000002d36bcf7 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 20. asan_thread_start(void*) @ 0x000000000aa43059 21. ? @ 0x00007f35aab92ac3 22. ? @ 0x00007f35aac24850 2025.09.09 15:08:02.389136 [ 20881 ] {bc73bb13-4dae-44e5-9624-5d170bafaf0c} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(equals(__table1.dummy, 0_UInt8) :: 0) -> throwIf(equals(__table1.dummy, 0_UInt8)) UInt8 : 1'. (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000aad4b34 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001859ee9c 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aac9135 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000cccce5b 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccce65c 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd2030 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x00000000286fc2bd 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000002d9c29ae 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000002d34877c 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000002d34827b 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*) @ 0x000000002d36bcf7 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 20. asan_thread_start(void*) @ 0x000000000aa43059 21. ? @ 0x00007f35aab92ac3 22. ? @ 0x00007f35aac24850 2025.09.09 15:08:02.398798 [ 20350 ] {18eeabba-a93b-4f75-a5a0-a145b9353ba3} executeQuery: Code: 395. DB::Exception: Received from 127.1:9000. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(equals(__table1.dummy, 0_UInt8) :: 0) -> throwIf(equals(__table1.dummy, 0_UInt8)) UInt8 : 1'. Stack trace: 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000aad4b34 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001859ee9c 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aac9135 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000cccce5b 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccce65c 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd2030 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x00000000286fc2bd 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000002d9c29ae 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000002d34877c 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000002d34827b 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*) @ 0x000000002d36bcf7 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 20. asan_thread_start(void*) @ 0x000000000aa43059 21. ? @ 0x00007f35aab92ac3 22. ? @ 0x00007f35aac24850 : While executing Remote. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:58392) (comment: 01752_distributed_query_sigsegv.sql) (in query: SELECT throwIf(dummy = 0) FROM remote('127.{1,2}', system.one) SETTINGS prefer_localhost_replica=0, distributed_group_by_no_merge=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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. ./contrib/llvm-project/libcxx/include/string:1499: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x000000001aeb974e 3. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::Connection::receiveException() const @ 0x000000002cee6c6a 4. ./build_docker/./src/Client/Connection.cpp:0: DB::Connection::receivePacket() @ 0x000000002cef780e 5. ./build_docker/./src/Client/PacketReceiver.cpp:0: DB::PacketReceiver::Task::run(std::function, std::function) @ 0x000000002cf9767e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000278ab436 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000278aaa44 8. ./contrib/boost/boost/context/fiber_ucontext.hpp:82: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x00000000278a8394 2025.09.09 15:08:02.401362 [ 20882 ] {af8e7370-7de2-47ef-ae0b-0d2b1bd50aee} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(equals(__table1.dummy, 0_UInt8) :: 0) -> throwIf(equals(__table1.dummy, 0_UInt8)) UInt8 : 1'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10505.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:40726) (comment: 01752_distributed_query_sigsegv.sql) (in query: SELECT throwIf(`__table1`.`dummy` = 0) AS `throwIf(equals(dummy, 0))` FROM `system`.`one` AS `__table1`), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000aad4b34 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001859ee9c 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aac9135 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000cccce5b 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccce65c 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd2030 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x00000000286fc2bd 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000002d9c29ae 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000002d34877c 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000002d34827b 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*) @ 0x000000002d36bcf7 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 20. asan_thread_start(void*) @ 0x000000000aa43059 21. ? @ 0x00007f35aab92ac3 22. ? @ 0x00007f35aac24850 2025.09.09 15:08:02.401778 [ 20350 ] {18eeabba-a93b-4f75-a5a0-a145b9353ba3} TCPHandler: Code: 395. DB::Exception: Received from 127.1:9000. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(equals(__table1.dummy, 0_UInt8) :: 0) -> throwIf(equals(__table1.dummy, 0_UInt8)) UInt8 : 1'. Stack trace: 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000aad4b34 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001859ee9c 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aac9135 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000cccce5b 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccce65c 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd2030 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x00000000286fc2bd 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000002d9c29ae 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000002d34877c 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000002d34827b 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*) @ 0x000000002d36bcf7 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 20. asan_thread_start(void*) @ 0x000000000aa43059 21. ? @ 0x00007f35aab92ac3 22. ? @ 0x00007f35aac24850 : 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. ./contrib/llvm-project/libcxx/include/string:1499: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x000000001aeb974e 3. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::Connection::receiveException() const @ 0x000000002cee6c6a 4. ./build_docker/./src/Client/Connection.cpp:0: DB::Connection::receivePacket() @ 0x000000002cef780e 5. ./build_docker/./src/Client/PacketReceiver.cpp:0: DB::PacketReceiver::Task::run(std::function, std::function) @ 0x000000002cf9767e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000278ab436 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000278aaa44 8. ./contrib/boost/boost/context/fiber_ucontext.hpp:82: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x00000000278a8394 2025.09.09 15:08:02.405579 [ 20882 ] {af8e7370-7de2-47ef-ae0b-0d2b1bd50aee} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(equals(__table1.dummy, 0_UInt8) :: 0) -> throwIf(equals(__table1.dummy, 0_UInt8)) UInt8 : 1'. (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000aad4b34 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001859ee9c 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aac9135 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000cccce5b 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccce65c 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd2030 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x00000000286fc2bd 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000002d9c29ae 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000002d34877c 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000002d34827b 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*) @ 0x000000002d36bcf7 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 20. asan_thread_start(void*) @ 0x000000000aa43059 21. ? @ 0x00007f35aab92ac3 22. ? @ 0x00007f35aac24850 2025.09.09 15:08:02.472118 [ 20345 ] {d7bace75-6199-4fe0-8c56-2abe150319f7} executeQuery: Code: 43. DB::Exception: First argument for function countEqual must be an array. Actual Nullable(Nothing): In scope SELECT countEqual(NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT countEqual(NULL, NULL);) 2025.09.09 15:08:02.474427 [ 20345 ] {d7bace75-6199-4fe0-8c56-2abe150319f7} TCPHandler: Code: 43. DB::Exception: First argument for function countEqual must be an array. Actual Nullable(Nothing): In scope SELECT countEqual(NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.09.09 15:08:02.505678 [ 3222 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:08:02.867722 [ 3220 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:08:02.883715 [ 3230 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:08:02.967495 [ 2772 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:08:03.079335 [ 20882 ] {6d51c44b-4e38-4309-95ce-106e469e5b52} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=790, jobs=739). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:58494) (comment: 00951_ngram_search.sql) (in query: select round(1000 * ngramSearchUTF8(materialize('абв'), '')) from system.numbers limit 5;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af872f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af7b2d1 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af7c3f3 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d36920d 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000002d369e5f 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processOrdinaryQuery() @ 0x000000002d18af7b 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d17644a 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 15. asan_thread_start(void*) @ 0x000000000aa43059 16. ? @ 0x00007f35aab92ac3 17. ? @ 0x00007f35aac24850 2025.09.09 15:08:03.086684 [ 20882 ] {6d51c44b-4e38-4309-95ce-106e469e5b52} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=790, 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af872f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af7b2d1 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af7c3f3 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d36920d 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000002d369e5f 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processOrdinaryQuery() @ 0x000000002d18af7b 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d17644a 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 15. asan_thread_start(void*) @ 0x000000000aa43059 16. ? @ 0x00007f35aab92ac3 17. ? @ 0x00007f35aac24850 2025.09.09 15:08:03.507616 [ 2886 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:08:03.870872 [ 2841 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:08:03.885757 [ 2909 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:08:03.969392 [ 2815 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:08:04.380642 [ 20345 ] {a973484a-fda9-4cbc-b720-555d1e387547} executeQuery: Code: 42. DB::Exception: Number of arguments for function today doesn't match: passed 2, should be 0: In scope SELECT curdate(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT curdate(NULL, NULL);) 2025.09.09 15:08:04.385670 [ 20345 ] {a973484a-fda9-4cbc-b720-555d1e387547} TCPHandler: Code: 42. DB::Exception: Number of arguments for function today doesn't match: passed 2, should be 0: In scope SELECT curdate(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:08:04.442852 [ 20345 ] {2500293f-d763-4a76-9b96-13cac7ae42d2} executeQuery: Code: 42. DB::Exception: Number of arguments for function currentDatabase doesn't match: passed 2, should be 0: In scope SELECT currentDatabase(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT currentDatabase(NULL, NULL);) 2025.09.09 15:08:04.450094 [ 20345 ] {2500293f-d763-4a76-9b96-13cac7ae42d2} TCPHandler: Code: 42. DB::Exception: Number of arguments for function currentDatabase doesn't match: passed 2, should be 0: In scope SELECT currentDatabase(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:08:04.542994 [ 20345 ] {cfdf09f3-f65a-43ab-940e-c5bc7d4882af} executeQuery: Code: 42. DB::Exception: Number of arguments for function currentProfiles doesn't match: passed 2, should be 0: In scope SELECT currentProfiles(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT currentProfiles(NULL, NULL);) 2025.09.09 15:08:04.545694 [ 20345 ] {cfdf09f3-f65a-43ab-940e-c5bc7d4882af} TCPHandler: Code: 42. DB::Exception: Number of arguments for function currentProfiles doesn't match: passed 2, should be 0: In scope SELECT currentProfiles(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:08:04.574747 [ 2963 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:08:04.636128 [ 20345 ] {ede61d93-617f-4785-9046-72e64d8b0085} executeQuery: Code: 42. DB::Exception: Number of arguments for function currentRoles doesn't match: passed 2, should be 0: In scope SELECT currentRoles(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT currentRoles(NULL, NULL);) 2025.09.09 15:08:04.641164 [ 20345 ] {ede61d93-617f-4785-9046-72e64d8b0085} TCPHandler: Code: 42. DB::Exception: Number of arguments for function currentRoles doesn't match: passed 2, should be 0: In scope SELECT currentRoles(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:08:04.734583 [ 20345 ] {87552402-dbf7-4926-b607-6de911dd0cb0} executeQuery: Code: 42. DB::Exception: Number of arguments for function currentSchemas doesn't match: passed 2, should be 1: In scope SELECT currentSchemas(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT currentSchemas(NULL, NULL);) 2025.09.09 15:08:04.738807 [ 20345 ] {87552402-dbf7-4926-b607-6de911dd0cb0} TCPHandler: Code: 42. DB::Exception: Number of arguments for function currentSchemas doesn't match: passed 2, should be 1: In scope SELECT currentSchemas(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:08:04.858199 [ 20345 ] {166ac293-958f-41f7-80b1-fa6a4bca45fa} executeQuery: Code: 42. DB::Exception: Number of arguments for function currentUser doesn't match: passed 2, should be 0: In scope SELECT currentUser(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT currentUser(NULL, NULL);) 2025.09.09 15:08:04.873826 [ 20345 ] {166ac293-958f-41f7-80b1-fa6a4bca45fa} TCPHandler: Code: 42. DB::Exception: Number of arguments for function currentUser doesn't match: passed 2, should be 0: In scope SELECT currentUser(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:08:04.940453 [ 20345 ] {bdab018c-9b9d-4253-a6ea-ba335d557b40} executeQuery: Code: 42. DB::Exception: Number of arguments for function currentDatabase doesn't match: passed 2, should be 0: In scope SELECT current_database(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT current_database(NULL, NULL);) 2025.09.09 15:08:04.942401 [ 2949 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:08:04.943251 [ 2871 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:08:04.944325 [ 20345 ] {bdab018c-9b9d-4253-a6ea-ba335d557b40} TCPHandler: Code: 42. DB::Exception: Number of arguments for function currentDatabase doesn't match: passed 2, should be 0: In scope SELECT current_database(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:08:04.971340 [ 2974 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:08:04.980587 [ 20345 ] {10c3db9d-2df9-4dee-a541-bbeee3ae5f03} executeQuery: Code: 42. DB::Exception: Number of arguments for function today doesn't match: passed 2, should be 0: In scope SELECT current_date(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT current_date(NULL, NULL);) 2025.09.09 15:08:04.984406 [ 20345 ] {10c3db9d-2df9-4dee-a541-bbeee3ae5f03} TCPHandler: Code: 42. DB::Exception: Number of arguments for function today doesn't match: passed 2, should be 0: In scope SELECT current_date(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:08:05.048232 [ 20345 ] {018b4290-6973-4050-acdf-b37b58f9eba8} executeQuery: Code: 42. DB::Exception: Number of arguments for function currentSchemas doesn't match: passed 2, should be 1: In scope SELECT current_schemas(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT current_schemas(NULL, NULL);) 2025.09.09 15:08:05.062216 [ 20345 ] {018b4290-6973-4050-acdf-b37b58f9eba8} TCPHandler: Code: 42. DB::Exception: Number of arguments for function currentSchemas doesn't match: passed 2, should be 1: In scope SELECT current_schemas(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:08:05.378372 [ 20345 ] {ece9af88-76a3-4e2b-bdb1-6921abb1f374} executeQuery: Code: 42. DB::Exception: Arguments size of function now should be 0 or 1: In scope SELECT current_timestamp(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT current_timestamp(NULL, NULL);) 2025.09.09 15:08:05.382087 [ 20345 ] {ece9af88-76a3-4e2b-bdb1-6921abb1f374} TCPHandler: Code: 42. DB::Exception: Arguments size of function now should be 0 or 1: In scope SELECT current_timestamp(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:08:05.497776 [ 20345 ] {23ea8274-10dc-4fc0-bb92-c9a89274b21c} executeQuery: Code: 42. DB::Exception: Number of arguments for function currentUser doesn't match: passed 2, should be 0: In scope SELECT current_user(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT current_user(NULL, NULL);) 2025.09.09 15:08:05.502499 [ 20345 ] {23ea8274-10dc-4fc0-bb92-c9a89274b21c} TCPHandler: Code: 42. DB::Exception: Number of arguments for function currentUser doesn't match: passed 2, should be 0: In scope SELECT current_user(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:08:05.576372 [ 3002 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:08:05.584329 [ 20345 ] {375fbcb0-2dcc-477f-b087-e2c5d1078619} executeQuery: Code: 42. DB::Exception: Number of arguments for function cutFragment doesn't match: passed 2, should be 1: In scope SELECT cutFragment(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT cutFragment(NULL, NULL);) 2025.09.09 15:08:05.590713 [ 20345 ] {375fbcb0-2dcc-477f-b087-e2c5d1078619} TCPHandler: Code: 42. DB::Exception: Number of arguments for function cutFragment doesn't match: passed 2, should be 1: In scope SELECT cutFragment(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:08:05.648283 [ 20345 ] {bca9c8e0-8328-460b-a8d5-6b1474aa637e} executeQuery: Code: 42. DB::Exception: Number of arguments for function cutIPv6 doesn't match: passed 2, should be 3: In scope SELECT cutIPv6(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT cutIPv6(NULL, NULL);) 2025.09.09 15:08:05.654609 [ 20345 ] {bca9c8e0-8328-460b-a8d5-6b1474aa637e} TCPHandler: Code: 42. DB::Exception: Number of arguments for function cutIPv6 doesn't match: passed 2, should be 3: In scope SELECT cutIPv6(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:08:05.718769 [ 20345 ] {6d2d0b87-9f40-4bd7-a586-aba2bf8aca72} executeQuery: Code: 42. DB::Exception: Number of arguments for function cutQueryString doesn't match: passed 2, should be 1: In scope SELECT cutQueryString(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT cutQueryString(NULL, NULL);) 2025.09.09 15:08:05.723758 [ 20345 ] {6d2d0b87-9f40-4bd7-a586-aba2bf8aca72} TCPHandler: Code: 42. DB::Exception: Number of arguments for function cutQueryString doesn't match: passed 2, should be 1: In scope SELECT cutQueryString(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:08:05.765822 [ 20345 ] {6c99a45a-b633-4acb-bb06-9fc4b8e25866} executeQuery: Code: 42. DB::Exception: Number of arguments for function cutQueryStringAndFragment doesn't match: passed 2, should be 1: In scope SELECT cutQueryStringAndFragment(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT cutQueryStringAndFragment(NULL, NULL);) 2025.09.09 15:08:05.771735 [ 20345 ] {6c99a45a-b633-4acb-bb06-9fc4b8e25866} TCPHandler: Code: 42. DB::Exception: Number of arguments for function cutQueryStringAndFragment doesn't match: passed 2, should be 1: In scope SELECT cutQueryStringAndFragment(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:08:05.893549 [ 20345 ] {a2ed6fe4-f5e5-48ee-a8ea-3ea80ab53e0f} executeQuery: Code: 42. DB::Exception: Number of arguments for function cutToFirstSignificantSubdomain doesn't match: passed 2, should be 1: In scope SELECT cutToFirstSignificantSubdomain(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT cutToFirstSignificantSubdomain(NULL, NULL);) 2025.09.09 15:08:05.897749 [ 20345 ] {a2ed6fe4-f5e5-48ee-a8ea-3ea80ab53e0f} TCPHandler: Code: 42. DB::Exception: Number of arguments for function cutToFirstSignificantSubdomain doesn't match: passed 2, should be 1: In scope SELECT cutToFirstSignificantSubdomain(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:08:05.943978 [ 3054 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:08:05.945472 [ 3027 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:08:05.973528 [ 3040 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:08:06.112501 [ 20353 ] {3f91da6b-eaad-45aa-b698-eca3b35f1d65} executeQuery: Code: 636. DB::Exception: The table structure cannot be extracted from a Native format file. Error: Code: 128. DB::Exception: Array sizes are too large: 13830481612736675823. (TOO_LARGE_ARRAY_SIZE) (version 24.8.14.10505.altinitytest (altinity build)). You can specify the structure manually. (CANNOT_EXTRACT_TABLE_STRUCTURE) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:58554) (comment: 02426_pod_array_overflow_2.sql) (in query: SELECT * FROM format(Native, 'k0\x23Array(Tuple(FixedString(1), Int64))\0\0\0\0\0\0\0�����\0����������������\0�\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0d\0\0\0\0\0\0\0\0\0\0\0\0\0�1?Vi�%');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&, String&) @ 0x00000000180b4b3a 4. ./build_docker/./src/Formats/ReadSchemaUtils.cpp:280: DB::readSchemaFromFormatImpl(std::optional, std::optional const&, DB::IReadBufferIterator&, std::shared_ptr const&) @ 0x000000002d2c2ce6 5. ./build_docker/./src/Formats/ReadSchemaUtils.cpp:0: DB::readSchemaFromFormat(String const&, std::optional const&, DB::IReadBufferIterator&, std::shared_ptr const&) @ 0x000000002d2c4e9b 6. ./build_docker/./src/TableFunctions/TableFunctionFormat.cpp:0: DB::(anonymous namespace)::TableFunctionFormat::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x0000000026040290 7. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x00000000265c241e 8. ./build_docker/./src/Interpreters/Context.cpp:2234: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000285361d2 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4819: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000002837024e 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000283ba404 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002835ad09 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000028359104 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000028357f0d 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002921bdcc 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&) @ 0x000000002941f313 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&) @ 0x0000000029419aef 17. ./contrib/llvm-project/libcxx/include/vector:432: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000029421f5d 18. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000029344c1b 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*) @ 0x0000000029b3703b 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 21. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 22. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 26. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 27. asan_thread_start(void*) @ 0x000000000aa43059 28. ? @ 0x00007f35aab92ac3 29. ? @ 0x00007f35aac24850 2025.09.09 15:08:06.117878 [ 20353 ] {3f91da6b-eaad-45aa-b698-eca3b35f1d65} TCPHandler: Code: 636. DB::Exception: The table structure cannot be extracted from a Native format file. Error: Code: 128. DB::Exception: Array sizes are too large: 13830481612736675823. (TOO_LARGE_ARRAY_SIZE) (version 24.8.14.10505.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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&, String&) @ 0x00000000180b4b3a 4. ./build_docker/./src/Formats/ReadSchemaUtils.cpp:280: DB::readSchemaFromFormatImpl(std::optional, std::optional const&, DB::IReadBufferIterator&, std::shared_ptr const&) @ 0x000000002d2c2ce6 5. ./build_docker/./src/Formats/ReadSchemaUtils.cpp:0: DB::readSchemaFromFormat(String const&, std::optional const&, DB::IReadBufferIterator&, std::shared_ptr const&) @ 0x000000002d2c4e9b 6. ./build_docker/./src/TableFunctions/TableFunctionFormat.cpp:0: DB::(anonymous namespace)::TableFunctionFormat::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x0000000026040290 7. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x00000000265c241e 8. ./build_docker/./src/Interpreters/Context.cpp:2234: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000285361d2 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4819: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000002837024e 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000283ba404 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002835ad09 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000028359104 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000028357f0d 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002921bdcc 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&) @ 0x000000002941f313 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&) @ 0x0000000029419aef 17. ./contrib/llvm-project/libcxx/include/vector:432: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000029421f5d 18. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000029344c1b 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*) @ 0x0000000029b3703b 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 21. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 22. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 26. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 27. asan_thread_start(void*) @ 0x000000000aa43059 28. ? @ 0x00007f35aab92ac3 29. ? @ 0x00007f35aac24850 2025.09.09 15:08:06.277019 [ 20338 ] {1cec0cb7-18fc-4b4e-9621-d22cf4672de5} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=13, jobs=0): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:58510) (comment: 02932_analyzer_rewrite_sum_column_and_constant.sql) (in query: -- { echoOn } SELECT sum(uint64 + 1 AS i) from test_table where i > 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af80b71 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80746 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002c765aab 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:1197: ? @ 0x000000002c7602b8 8. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x000000002c75fc2b 9. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:0: DB::MergeTreeReaderCompact::MergeTreeReaderCompact(std::shared_ptr, DB::NamesAndTypesList, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*, DB::MarkCache*, DB::MarkRanges, DB::MergeTreeReaderSettings, std::map, std::allocator>>, std::function const&, int) @ 0x000000002c7aee03 10. ./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.h:16: DB::MergeTreeReaderCompactSingleBuffer::MergeTreeReaderCompactSingleBuffer&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int&&) @ 0x000000002c5d6d21 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::MergeTreeDataPartCompact::getReader(DB::NamesAndTypesList const&, std::shared_ptr const&, DB::MarkRanges const&, std::unordered_map, std::equal_to, std::allocator>> const&, DB::UncompressedCache*, DB::MarkCache*, std::shared_ptr const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) const @ 0x000000002c5d1037 12. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:44: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x000000002c82a56b 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:295: DB::MergeTreeReadPoolBase::createTask(std::shared_ptr, DB::MarkRanges, DB::MergeTreeReadTask*) const @ 0x000000002de9c234 14. ./build_docker/./src/Storages/MergeTree/MergeTreeReadPoolInOrder.cpp:72: DB::MergeTreeReadPoolInOrder::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x000000002deff671 15. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectAlgorithms.cpp:17: DB::MergeTreeInOrderSelectAlgorithm::getNewTask(DB::IMergeTreeReadPool&, DB::MergeTreeReadTask*) @ 0x000000002dea3919 16. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:0: DB::MergeTreeSelectProcessor::read() @ 0x000000002c8241d2 17. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000002de6d77a 18. ./build_docker/./src/Processors/ISource.cpp:0: DB::ISource::work() @ 0x000000002d3290a1 19. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 20. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 21. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000002d34877c 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000002d34827b 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*) @ 0x000000002d36bcf7 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 26. asan_thread_start(void*) @ 0x000000000aa43059 27. ? @ 0x00007f35aab92ac3 28. ? @ 0x00007f35aac24850 2025.09.09 15:08:06.279439 [ 20338 ] {1cec0cb7-18fc-4b4e-9621-d22cf4672de5} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=13, jobs=0): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af80b71 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80746 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002c765aab 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:1197: ? @ 0x000000002c7602b8 8. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x000000002c75fc2b 9. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:0: DB::MergeTreeReaderCompact::MergeTreeReaderCompact(std::shared_ptr, DB::NamesAndTypesList, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*, DB::MarkCache*, DB::MarkRanges, DB::MergeTreeReaderSettings, std::map, std::allocator>>, std::function const&, int) @ 0x000000002c7aee03 10. ./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.h:16: DB::MergeTreeReaderCompactSingleBuffer::MergeTreeReaderCompactSingleBuffer&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int&&) @ 0x000000002c5d6d21 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::MergeTreeDataPartCompact::getReader(DB::NamesAndTypesList const&, std::shared_ptr const&, DB::MarkRanges const&, std::unordered_map, std::equal_to, std::allocator>> const&, DB::UncompressedCache*, DB::MarkCache*, std::shared_ptr const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) const @ 0x000000002c5d1037 12. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:44: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x000000002c82a56b 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:295: DB::MergeTreeReadPoolBase::createTask(std::shared_ptr, DB::MarkRanges, DB::MergeTreeReadTask*) const @ 0x000000002de9c234 14. ./build_docker/./src/Storages/MergeTree/MergeTreeReadPoolInOrder.cpp:72: DB::MergeTreeReadPoolInOrder::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x000000002deff671 15. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectAlgorithms.cpp:17: DB::MergeTreeInOrderSelectAlgorithm::getNewTask(DB::IMergeTreeReadPool&, DB::MergeTreeReadTask*) @ 0x000000002dea3919 16. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:0: DB::MergeTreeSelectProcessor::read() @ 0x000000002c8241d2 17. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000002de6d77a 18. ./build_docker/./src/Processors/ISource.cpp:0: DB::ISource::work() @ 0x000000002d3290a1 19. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 20. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 21. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000002d34877c 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000002d34827b 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*) @ 0x000000002d36bcf7 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 26. asan_thread_start(void*) @ 0x000000000aa43059 27. ? @ 0x00007f35aab92ac3 28. ? @ 0x00007f35aac24850 2025.09.09 15:08:06.433645 [ 20345 ] {a95b687c-3bf2-4e50-812b-230d049fb933} executeQuery: Code: 42. DB::Exception: Number of arguments for function cutToFirstSignificantSubdomainRFC doesn't match: passed 2, should be 1: In scope SELECT cutToFirstSignificantSubdomainRFC(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT cutToFirstSignificantSubdomainRFC(NULL, NULL);) 2025.09.09 15:08:06.441268 [ 20345 ] {a95b687c-3bf2-4e50-812b-230d049fb933} TCPHandler: Code: 42. DB::Exception: Number of arguments for function cutToFirstSignificantSubdomainRFC doesn't match: passed 2, should be 1: In scope SELECT cutToFirstSignificantSubdomainRFC(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:08:06.495495 [ 20881 ] {362c8fd9-80a2-4970-8d6b-00de8d45b8bc} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:43254) (comment: 02932_analyzer_rewrite_sum_column_and_constant.sql) (in query: DROP DATABASE IF EXISTS test_edglva1b ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aac868e 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x00000000286b57c7 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x00000000291f5630 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:361: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000291edc97 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x00000000291ebf11 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x00000000291eb7ed 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b382fc 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1529: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000029b3ed3f 11. ./build_docker/./src/Server/HTTPHandler.cpp:529: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000002d0662d1 12. ./build_docker/./src/Server/HTTPHandler.cpp:705: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000002d06d139 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000002d1cc337 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 18. asan_thread_start(void*) @ 0x000000000aa43059 19. ? @ 0x00007f35aab92ac3 20. ? @ 0x00007f35aac24850 2025.09.09 15:08:06.504523 [ 20881 ] {362c8fd9-80a2-4970-8d6b-00de8d45b8bc} DynamicQueryHandler: Code: 219. DB::Exception: New table 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aac868e 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x00000000286b57c7 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x00000000291f5630 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:361: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000291edc97 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x00000000291ebf11 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x00000000291eb7ed 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b382fc 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1529: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000029b3ed3f 11. ./build_docker/./src/Server/HTTPHandler.cpp:529: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000002d0662d1 12. ./build_docker/./src/Server/HTTPHandler.cpp:705: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000002d06d139 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000002d1cc337 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 18. asan_thread_start(void*) @ 0x000000000aa43059 19. ? @ 0x00007f35aab92ac3 20. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:08:06.516980 [ 20345 ] {b442ea34-1399-41b1-88b2-4bf625da0766} executeQuery: Code: 42. DB::Exception: Number of arguments for function cutToFirstSignificantSubdomainWithWWW doesn't match: passed 2, should be 1: In scope SELECT cutToFirstSignificantSubdomainWithWWW(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT cutToFirstSignificantSubdomainWithWWW(NULL, NULL);) 2025.09.09 15:08:06.524672 [ 20345 ] {b442ea34-1399-41b1-88b2-4bf625da0766} TCPHandler: Code: 42. DB::Exception: Number of arguments for function cutToFirstSignificantSubdomainWithWWW doesn't match: passed 2, should be 1: In scope SELECT cutToFirstSignificantSubdomainWithWWW(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:08:06.559633 [ 20338 ] {ae077ad7-bba0-487d-8a9a-6d75a808f346} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:43256) (comment: 02932_analyzer_rewrite_sum_column_and_constant.sql) (in query: DROP DATABASE IF EXISTS test_edglva1b ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aac868e 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x00000000286b57c7 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x00000000291f5630 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:361: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000291edc97 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x00000000291ebf11 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x00000000291eb7ed 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b382fc 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1529: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000029b3ed3f 11. ./build_docker/./src/Server/HTTPHandler.cpp:529: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000002d0662d1 12. ./build_docker/./src/Server/HTTPHandler.cpp:705: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000002d06d139 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000002d1cc337 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 18. asan_thread_start(void*) @ 0x000000000aa43059 19. ? @ 0x00007f35aab92ac3 20. ? @ 0x00007f35aac24850 2025.09.09 15:08:06.561888 [ 20338 ] {ae077ad7-bba0-487d-8a9a-6d75a808f346} DynamicQueryHandler: Code: 219. DB::Exception: New table 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aac868e 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x00000000286b57c7 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x00000000291f5630 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:361: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000291edc97 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x00000000291ebf11 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x00000000291eb7ed 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b382fc 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1529: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000029b3ed3f 11. ./build_docker/./src/Server/HTTPHandler.cpp:529: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000002d0662d1 12. ./build_docker/./src/Server/HTTPHandler.cpp:705: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000002d06d139 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000002d1cc337 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 18. asan_thread_start(void*) @ 0x000000000aa43059 19. ? @ 0x00007f35aab92ac3 20. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:08:06.583090 [ 3114 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:08:06.604374 [ 20345 ] {eee51ebb-f1cf-4fbd-bf35-7338a303bcab} executeQuery: Code: 42. DB::Exception: Number of arguments for function cutToFirstSignificantSubdomainWithWWWRFC doesn't match: passed 2, should be 1: In scope SELECT cutToFirstSignificantSubdomainWithWWWRFC(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT cutToFirstSignificantSubdomainWithWWWRFC(NULL, NULL);) 2025.09.09 15:08:06.610584 [ 20345 ] {eee51ebb-f1cf-4fbd-bf35-7338a303bcab} TCPHandler: Code: 42. DB::Exception: Number of arguments for function cutToFirstSignificantSubdomainWithWWWRFC doesn't match: passed 2, should be 1: In scope SELECT cutToFirstSignificantSubdomainWithWWWRFC(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:08:06.730263 [ 20881 ] {8aa93472-fcc5-4556-af17-28420f5d27f4} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:43272) (comment: 02932_analyzer_rewrite_sum_column_and_constant.sql) (in query: DROP DATABASE IF EXISTS test_edglva1b ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aac868e 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x00000000286b57c7 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x00000000291f5630 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:361: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000291edc97 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x00000000291ebf11 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x00000000291eb7ed 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b382fc 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1529: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000029b3ed3f 11. ./build_docker/./src/Server/HTTPHandler.cpp:529: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000002d0662d1 12. ./build_docker/./src/Server/HTTPHandler.cpp:705: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000002d06d139 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000002d1cc337 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 18. asan_thread_start(void*) @ 0x000000000aa43059 19. ? @ 0x00007f35aab92ac3 20. ? @ 0x00007f35aac24850 2025.09.09 15:08:06.736845 [ 20881 ] {8aa93472-fcc5-4556-af17-28420f5d27f4} DynamicQueryHandler: Code: 219. DB::Exception: New table 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aac868e 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x00000000286b57c7 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x00000000291f5630 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:361: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000291edc97 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x00000000291ebf11 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x00000000291eb7ed 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b382fc 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1529: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000029b3ed3f 11. ./build_docker/./src/Server/HTTPHandler.cpp:529: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000002d0662d1 12. ./build_docker/./src/Server/HTTPHandler.cpp:705: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000002d06d139 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000002d1cc337 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 18. asan_thread_start(void*) @ 0x000000000aa43059 19. ? @ 0x00007f35aab92ac3 20. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:08:06.872534 [ 20345 ] {00d93686-c974-4347-a219-996d1163e668} executeQuery: Code: 42. DB::Exception: Number of arguments for function cutWWW doesn't match: passed 2, should be 1: In scope SELECT cutWWW(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT cutWWW(NULL, NULL);) 2025.09.09 15:08:06.890470 [ 20345 ] {00d93686-c974-4347-a219-996d1163e668} TCPHandler: Code: 42. DB::Exception: Number of arguments for function cutWWW doesn't match: passed 2, should be 1: In scope SELECT cutWWW(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:08:06.937755 [ 20338 ] {ac90f4a4-f2a7-4dc7-ba94-191fe2bb7001} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:43278) (comment: 02932_analyzer_rewrite_sum_column_and_constant.sql) (in query: DROP DATABASE IF EXISTS test_edglva1b ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aac868e 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x00000000286b57c7 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x00000000291f5630 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:361: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000291edc97 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x00000000291ebf11 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x00000000291eb7ed 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b382fc 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1529: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000029b3ed3f 11. ./build_docker/./src/Server/HTTPHandler.cpp:529: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000002d0662d1 12. ./build_docker/./src/Server/HTTPHandler.cpp:705: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000002d06d139 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000002d1cc337 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 18. asan_thread_start(void*) @ 0x000000000aa43059 19. ? @ 0x00007f35aab92ac3 20. ? @ 0x00007f35aac24850 2025.09.09 15:08:06.944818 [ 20338 ] {ac90f4a4-f2a7-4dc7-ba94-191fe2bb7001} DynamicQueryHandler: Code: 219. DB::Exception: New table 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aac868e 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x00000000286b57c7 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x00000000291f5630 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:361: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000291edc97 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x00000000291ebf11 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x00000000291eb7ed 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b382fc 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1529: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000029b3ed3f 11. ./build_docker/./src/Server/HTTPHandler.cpp:529: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000002d0662d1 12. ./build_docker/./src/Server/HTTPHandler.cpp:705: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000002d06d139 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000002d1cc337 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 18. asan_thread_start(void*) @ 0x000000000aa43059 19. ? @ 0x00007f35aab92ac3 20. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:08:06.946621 [ 3143 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:08:06.952649 [ 3129 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:08:06.984602 [ 3119 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:08:07.096086 [ 20881 ] {73b1c65f-c984-41f0-82aa-61df33f529ce} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:43280) (comment: 02932_analyzer_rewrite_sum_column_and_constant.sql) (in query: DROP DATABASE IF EXISTS test_edglva1b ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aac868e 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x00000000286b57c7 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x00000000291f5630 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:361: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000291edc97 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x00000000291ebf11 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x00000000291eb7ed 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b382fc 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1529: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000029b3ed3f 11. ./build_docker/./src/Server/HTTPHandler.cpp:529: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000002d0662d1 12. ./build_docker/./src/Server/HTTPHandler.cpp:705: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000002d06d139 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000002d1cc337 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 18. asan_thread_start(void*) @ 0x000000000aa43059 19. ? @ 0x00007f35aab92ac3 20. ? @ 0x00007f35aac24850 2025.09.09 15:08:07.100077 [ 20881 ] {73b1c65f-c984-41f0-82aa-61df33f529ce} DynamicQueryHandler: Code: 219. DB::Exception: New table 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aac868e 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x00000000286b57c7 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x00000000291f5630 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:361: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000291edc97 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x00000000291ebf11 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x00000000291eb7ed 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b382fc 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1529: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000029b3ed3f 11. ./build_docker/./src/Server/HTTPHandler.cpp:529: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000002d0662d1 12. ./build_docker/./src/Server/HTTPHandler.cpp:705: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000002d06d139 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000002d1cc337 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 18. asan_thread_start(void*) @ 0x000000000aa43059 19. ? @ 0x00007f35aab92ac3 20. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:08:07.289037 [ 20338 ] {7aaa0f3f-bc49-4b6a-9417-90a6896d6478} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:43290) (comment: 02932_analyzer_rewrite_sum_column_and_constant.sql) (in query: DROP DATABASE IF EXISTS test_edglva1b ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aac868e 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x00000000286b57c7 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x00000000291f5630 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:361: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000291edc97 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x00000000291ebf11 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x00000000291eb7ed 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b382fc 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1529: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000029b3ed3f 11. ./build_docker/./src/Server/HTTPHandler.cpp:529: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000002d0662d1 12. ./build_docker/./src/Server/HTTPHandler.cpp:705: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000002d06d139 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000002d1cc337 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 18. asan_thread_start(void*) @ 0x000000000aa43059 19. ? @ 0x00007f35aab92ac3 20. ? @ 0x00007f35aac24850 2025.09.09 15:08:07.296384 [ 20338 ] {7aaa0f3f-bc49-4b6a-9417-90a6896d6478} DynamicQueryHandler: Code: 219. DB::Exception: New table 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aac868e 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x00000000286b57c7 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x00000000291f5630 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:361: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000291edc97 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x00000000291ebf11 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x00000000291eb7ed 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b382fc 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1529: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000029b3ed3f 11. ./build_docker/./src/Server/HTTPHandler.cpp:529: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000002d0662d1 12. ./build_docker/./src/Server/HTTPHandler.cpp:705: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000002d06d139 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000002d1cc337 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 18. asan_thread_start(void*) @ 0x000000000aa43059 19. ? @ 0x00007f35aab92ac3 20. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:08:07.356051 [ 20881 ] {2551844b-3abc-4f03-b81b-c633c32fbe9f} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:43296) (comment: 02932_analyzer_rewrite_sum_column_and_constant.sql) (in query: DROP DATABASE IF EXISTS test_edglva1b ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aac868e 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x00000000286b57c7 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x00000000291f5630 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:361: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000291edc97 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x00000000291ebf11 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x00000000291eb7ed 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b382fc 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1529: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000029b3ed3f 11. ./build_docker/./src/Server/HTTPHandler.cpp:529: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000002d0662d1 12. ./build_docker/./src/Server/HTTPHandler.cpp:705: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000002d06d139 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000002d1cc337 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 18. asan_thread_start(void*) @ 0x000000000aa43059 19. ? @ 0x00007f35aab92ac3 20. ? @ 0x00007f35aac24850 2025.09.09 15:08:07.363901 [ 20881 ] {2551844b-3abc-4f03-b81b-c633c32fbe9f} DynamicQueryHandler: Code: 219. DB::Exception: New table 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aac868e 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x00000000286b57c7 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x00000000291f5630 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:361: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000291edc97 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x00000000291ebf11 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x00000000291eb7ed 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b382fc 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1529: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000029b3ed3f 11. ./build_docker/./src/Server/HTTPHandler.cpp:529: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000002d0662d1 12. ./build_docker/./src/Server/HTTPHandler.cpp:705: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000002d06d139 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000002d1cc337 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 18. asan_thread_start(void*) @ 0x000000000aa43059 19. ? @ 0x00007f35aab92ac3 20. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:08:07.433805 [ 20345 ] {7c734a11-78c8-465d-96ee-e536070cfb2c} executeQuery: Code: 42. DB::Exception: Number of arguments for function dateTime64ToSnowflake doesn't match: passed 2, should be 1: In scope SELECT dateTime64ToSnowflake(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT dateTime64ToSnowflake(NULL, NULL);) 2025.09.09 15:08:07.439737 [ 20345 ] {7c734a11-78c8-465d-96ee-e536070cfb2c} TCPHandler: Code: 42. DB::Exception: Number of arguments for function dateTime64ToSnowflake doesn't match: passed 2, should be 1: In scope SELECT dateTime64ToSnowflake(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:08:07.508806 [ 20338 ] {e03bca17-b646-46c2-a9a5-619bd71edc0b} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:43304) (comment: 02932_analyzer_rewrite_sum_column_and_constant.sql) (in query: DROP DATABASE IF EXISTS test_edglva1b ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aac868e 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x00000000286b57c7 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x00000000291f5630 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:361: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000291edc97 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x00000000291ebf11 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x00000000291eb7ed 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b382fc 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1529: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000029b3ed3f 11. ./build_docker/./src/Server/HTTPHandler.cpp:529: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000002d0662d1 12. ./build_docker/./src/Server/HTTPHandler.cpp:705: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000002d06d139 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000002d1cc337 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 18. asan_thread_start(void*) @ 0x000000000aa43059 19. ? @ 0x00007f35aab92ac3 20. ? @ 0x00007f35aac24850 2025.09.09 15:08:07.515557 [ 20338 ] {e03bca17-b646-46c2-a9a5-619bd71edc0b} DynamicQueryHandler: Code: 219. DB::Exception: New table 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aac868e 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x00000000286b57c7 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x00000000291f5630 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:361: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000291edc97 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x00000000291ebf11 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x00000000291eb7ed 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b382fc 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1529: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000029b3ed3f 11. ./build_docker/./src/Server/HTTPHandler.cpp:529: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000002d0662d1 12. ./build_docker/./src/Server/HTTPHandler.cpp:705: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000002d06d139 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000002d1cc337 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 18. asan_thread_start(void*) @ 0x000000000aa43059 19. ? @ 0x00007f35aab92ac3 20. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:08:07.585829 [ 3192 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:08:07.653637 [ 20353 ] {5e61824f-1e4b-43da-b6d0-d9e40ee44e8f} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:43306) (comment: 02932_analyzer_rewrite_sum_column_and_constant.sql) (in query: DROP DATABASE IF EXISTS test_edglva1b ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aac868e 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x00000000286b57c7 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x00000000291f5630 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:361: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000291edc97 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x00000000291ebf11 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x00000000291eb7ed 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b382fc 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1529: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000029b3ed3f 11. ./build_docker/./src/Server/HTTPHandler.cpp:529: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000002d0662d1 12. ./build_docker/./src/Server/HTTPHandler.cpp:705: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000002d06d139 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000002d1cc337 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 18. asan_thread_start(void*) @ 0x000000000aa43059 19. ? @ 0x00007f35aab92ac3 20. ? @ 0x00007f35aac24850 2025.09.09 15:08:07.658040 [ 20353 ] {5e61824f-1e4b-43da-b6d0-d9e40ee44e8f} DynamicQueryHandler: Code: 219. DB::Exception: New table 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aac868e 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x00000000286b57c7 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x00000000291f5630 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:361: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000291edc97 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x00000000291ebf11 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x00000000291eb7ed 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b382fc 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1529: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000029b3ed3f 11. ./build_docker/./src/Server/HTTPHandler.cpp:529: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000002d0662d1 12. ./build_docker/./src/Server/HTTPHandler.cpp:705: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000002d06d139 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000002d1cc337 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 18. asan_thread_start(void*) @ 0x000000000aa43059 19. ? @ 0x00007f35aab92ac3 20. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:08:07.746722 [ 20345 ] {6d68291f-552b-4ecd-b353-44c71f0ec94a} executeQuery: Code: 42. DB::Exception: Number of arguments for function dateTimeToSnowflake doesn't match: passed 2, should be 1: In scope SELECT dateTimeToSnowflake(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT dateTimeToSnowflake(NULL, NULL);) 2025.09.09 15:08:07.753189 [ 20345 ] {6d68291f-552b-4ecd-b353-44c71f0ec94a} TCPHandler: Code: 42. DB::Exception: Number of arguments for function dateTimeToSnowflake doesn't match: passed 2, should be 1: In scope SELECT dateTimeToSnowflake(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:08:07.776047 [ 20338 ] {ae1fbfd2-f1ed-4078-a7eb-90662fd5e102} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:43312) (comment: 02932_analyzer_rewrite_sum_column_and_constant.sql) (in query: DROP DATABASE IF EXISTS test_edglva1b ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aac868e 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x00000000286b57c7 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x00000000291f5630 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:361: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000291edc97 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x00000000291ebf11 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x00000000291eb7ed 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b382fc 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1529: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000029b3ed3f 11. ./build_docker/./src/Server/HTTPHandler.cpp:529: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000002d0662d1 12. ./build_docker/./src/Server/HTTPHandler.cpp:705: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000002d06d139 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000002d1cc337 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 18. asan_thread_start(void*) @ 0x000000000aa43059 19. ? @ 0x00007f35aab92ac3 20. ? @ 0x00007f35aac24850 2025.09.09 15:08:07.781405 [ 20338 ] {ae1fbfd2-f1ed-4078-a7eb-90662fd5e102} DynamicQueryHandler: Code: 219. DB::Exception: New table 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aac868e 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x00000000286b57c7 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x00000000291f5630 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:361: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000291edc97 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x00000000291ebf11 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x00000000291eb7ed 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b382fc 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1529: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000029b3ed3f 11. ./build_docker/./src/Server/HTTPHandler.cpp:529: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000002d0662d1 12. ./build_docker/./src/Server/HTTPHandler.cpp:705: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000002d06d139 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000002d1cc337 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 18. asan_thread_start(void*) @ 0x000000000aa43059 19. ? @ 0x00007f35aab92ac3 20. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:08:07.943894 [ 20353 ] {68d5f056-5db1-49fd-99e6-6281119528a3} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:43322) (comment: 02932_analyzer_rewrite_sum_column_and_constant.sql) (in query: DROP DATABASE IF EXISTS test_edglva1b ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aac868e 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x00000000286b57c7 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x00000000291f5630 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:361: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000291edc97 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x00000000291ebf11 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x00000000291eb7ed 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b382fc 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1529: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000029b3ed3f 11. ./build_docker/./src/Server/HTTPHandler.cpp:529: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000002d0662d1 12. ./build_docker/./src/Server/HTTPHandler.cpp:705: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000002d06d139 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000002d1cc337 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 18. asan_thread_start(void*) @ 0x000000000aa43059 19. ? @ 0x00007f35aab92ac3 20. ? @ 0x00007f35aac24850 2025.09.09 15:08:07.956167 [ 3228 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:08:07.956763 [ 2742 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:08:07.971886 [ 20353 ] {68d5f056-5db1-49fd-99e6-6281119528a3} DynamicQueryHandler: Code: 219. DB::Exception: New table 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aac868e 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x00000000286b57c7 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x00000000291f5630 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:361: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000291edc97 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x00000000291ebf11 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x00000000291eb7ed 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b382fc 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1529: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000029b3ed3f 11. ./build_docker/./src/Server/HTTPHandler.cpp:529: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000002d0662d1 12. ./build_docker/./src/Server/HTTPHandler.cpp:705: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000002d06d139 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000002d1cc337 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 18. asan_thread_start(void*) @ 0x000000000aa43059 19. ? @ 0x00007f35aab92ac3 20. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:08:07.987922 [ 3231 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:08:08.068024 [ 20345 ] {ac2ab3a2-819c-4a56-90aa-3b5ab6ce9006} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=790, jobs=739). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT dateTrunc(NULL, NULL);) 2025.09.09 15:08:08.077653 [ 20345 ] {ac2ab3a2-819c-4a56-90aa-3b5ab6ce9006} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=790, jobs=739). (CANNOT_SCHEDULE_TASK) 2025.09.09 15:08:08.256256 [ 20351 ] {7997d020-ae80-4e27-a8f0-325d4e9b0762} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:47346) (comment: 02932_analyzer_rewrite_sum_column_and_constant.sql) (in query: DROP DATABASE IF EXISTS test_edglva1b ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aac868e 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x00000000286b57c7 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x00000000291f5630 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:361: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000291edc97 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x00000000291ebf11 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x00000000291eb7ed 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b382fc 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1529: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000029b3ed3f 11. ./build_docker/./src/Server/HTTPHandler.cpp:529: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000002d0662d1 12. ./build_docker/./src/Server/HTTPHandler.cpp:705: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000002d06d139 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000002d1cc337 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 18. asan_thread_start(void*) @ 0x000000000aa43059 19. ? @ 0x00007f35aab92ac3 20. ? @ 0x00007f35aac24850 2025.09.09 15:08:08.258541 [ 20351 ] {7997d020-ae80-4e27-a8f0-325d4e9b0762} DynamicQueryHandler: Code: 219. DB::Exception: New table 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aac868e 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x00000000286b57c7 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x00000000291f5630 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:361: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000291edc97 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x00000000291ebf11 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x00000000291eb7ed 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b382fc 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1529: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000029b3ed3f 11. ./build_docker/./src/Server/HTTPHandler.cpp:529: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000002d0662d1 12. ./build_docker/./src/Server/HTTPHandler.cpp:705: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000002d06d139 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000002d1cc337 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 18. asan_thread_start(void*) @ 0x000000000aa43059 19. ? @ 0x00007f35aab92ac3 20. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:08:08.269289 [ 20345 ] {a6a3a7c7-f9c9-4bc9-a6fe-dd91c33cc129} executeQuery: Code: 42. DB::Exception: Number of arguments for function decodeHTMLComponent doesn't match: passed 2, should be 1: In scope SELECT decodeHTMLComponent(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT decodeHTMLComponent(NULL, NULL);) 2025.09.09 15:08:08.272663 [ 20345 ] {a6a3a7c7-f9c9-4bc9-a6fe-dd91c33cc129} TCPHandler: Code: 42. DB::Exception: Number of arguments for function decodeHTMLComponent doesn't match: passed 2, should be 1: In scope SELECT decodeHTMLComponent(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:08:08.306654 [ 20353 ] {7d080f90-f573-47c6-8b7f-29c8b89685ea} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:47354) (comment: 02932_analyzer_rewrite_sum_column_and_constant.sql) (in query: DROP DATABASE IF EXISTS test_edglva1b ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aac868e 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x00000000286b57c7 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x00000000291f5630 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:361: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000291edc97 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x00000000291ebf11 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x00000000291eb7ed 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b382fc 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1529: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000029b3ed3f 11. ./build_docker/./src/Server/HTTPHandler.cpp:529: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000002d0662d1 12. ./build_docker/./src/Server/HTTPHandler.cpp:705: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000002d06d139 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000002d1cc337 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 18. asan_thread_start(void*) @ 0x000000000aa43059 19. ? @ 0x00007f35aab92ac3 20. ? @ 0x00007f35aac24850 2025.09.09 15:08:08.310248 [ 20353 ] {7d080f90-f573-47c6-8b7f-29c8b89685ea} DynamicQueryHandler: Code: 219. DB::Exception: New table 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aac868e 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x00000000286b57c7 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x00000000291f5630 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:361: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000291edc97 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x00000000291ebf11 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x00000000291eb7ed 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b382fc 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1529: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000029b3ed3f 11. ./build_docker/./src/Server/HTTPHandler.cpp:529: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000002d0662d1 12. ./build_docker/./src/Server/HTTPHandler.cpp:705: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000002d06d139 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000002d1cc337 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 18. asan_thread_start(void*) @ 0x000000000aa43059 19. ? @ 0x00007f35aab92ac3 20. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:08:08.323612 [ 20345 ] {47ebca40-ca94-4675-9777-aabdb2da9096} executeQuery: Code: 42. DB::Exception: Number of arguments for function decodeURLComponent doesn't match: passed 2, should be 1: In scope SELECT decodeURLComponent(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT decodeURLComponent(NULL, NULL);) 2025.09.09 15:08:08.326077 [ 20345 ] {47ebca40-ca94-4675-9777-aabdb2da9096} TCPHandler: Code: 42. DB::Exception: Number of arguments for function decodeURLComponent doesn't match: passed 2, should be 1: In scope SELECT decodeURLComponent(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:08:08.371764 [ 20345 ] {732c284a-8408-43e0-8f01-671ad7b3c286} executeQuery: Code: 42. DB::Exception: Number of arguments for function decodeURLFormComponent doesn't match: passed 2, should be 1: In scope SELECT decodeURLFormComponent(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT decodeURLFormComponent(NULL, NULL);) 2025.09.09 15:08:08.386803 [ 20345 ] {732c284a-8408-43e0-8f01-671ad7b3c286} TCPHandler: Code: 42. DB::Exception: Number of arguments for function decodeURLFormComponent doesn't match: passed 2, should be 1: In scope SELECT decodeURLFormComponent(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:08:08.446789 [ 20345 ] {1ce00cfb-f965-47e2-9fa4-5750ce4680f2} executeQuery: Code: 42. DB::Exception: Number of arguments for function decodeXMLComponent doesn't match: passed 2, should be 1: In scope SELECT decodeXMLComponent(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT decodeXMLComponent(NULL, NULL);) 2025.09.09 15:08:08.455236 [ 20345 ] {1ce00cfb-f965-47e2-9fa4-5750ce4680f2} TCPHandler: Code: 42. DB::Exception: Number of arguments for function decodeXMLComponent doesn't match: passed 2, should be 1: In scope SELECT decodeXMLComponent(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:08:08.587944 [ 2793 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:08:08.675109 [ 20345 ] {d5a0c819-779d-4cfb-938e-34f2399a33c1} executeQuery: Code: 42. DB::Exception: Number of arguments for function defaultProfiles doesn't match: passed 2, should be 0: In scope SELECT defaultProfiles(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT defaultProfiles(NULL, NULL);) 2025.09.09 15:08:08.679895 [ 20345 ] {d5a0c819-779d-4cfb-938e-34f2399a33c1} TCPHandler: Code: 42. DB::Exception: Number of arguments for function defaultProfiles doesn't match: passed 2, should be 0: In scope SELECT defaultProfiles(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:08:08.737755 [ 20345 ] {9f7ebdf6-5103-4f6b-b0b7-706069ac583c} executeQuery: Code: 42. DB::Exception: Number of arguments for function defaultRoles doesn't match: passed 2, should be 0: In scope SELECT defaultRoles(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT defaultRoles(NULL, NULL);) 2025.09.09 15:08:08.742260 [ 20345 ] {9f7ebdf6-5103-4f6b-b0b7-706069ac583c} TCPHandler: Code: 42. DB::Exception: Number of arguments for function defaultRoles doesn't match: passed 2, should be 0: In scope SELECT defaultRoles(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:08:08.787834 [ 20345 ] {29334ca8-427f-4e59-a06f-1a9a7b25164a} executeQuery: Code: 42. DB::Exception: Number of arguments for function defaultValueOfArgumentType doesn't match: passed 2, should be 1: In scope SELECT defaultValueOfArgumentType(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT defaultValueOfArgumentType(NULL, NULL);) 2025.09.09 15:08:08.792764 [ 20345 ] {29334ca8-427f-4e59-a06f-1a9a7b25164a} TCPHandler: Code: 42. DB::Exception: Number of arguments for function defaultValueOfArgumentType doesn't match: passed 2, should be 1: In scope SELECT defaultValueOfArgumentType(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:08:08.911479 [ 20345 ] {80edf1aa-e2e1-4590-8e98-7cbae1d79077} executeQuery: Code: 42. DB::Exception: Number of arguments for function defaultValueOfTypeName doesn't match: passed 2, should be 1: In scope SELECT defaultValueOfTypeName(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT defaultValueOfTypeName(NULL, NULL);) 2025.09.09 15:08:08.913781 [ 20345 ] {80edf1aa-e2e1-4590-8e98-7cbae1d79077} TCPHandler: Code: 42. DB::Exception: Number of arguments for function defaultValueOfTypeName doesn't match: passed 2, should be 1: In scope SELECT defaultValueOfTypeName(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:08:08.970279 [ 2819 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:08:08.970636 [ 2822 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:08:08.990381 [ 2813 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:08:09.006248 [ 20345 ] {ace59c79-7ca1-4c8e-9afc-6e3252b8dab8} executeQuery: Code: 42. DB::Exception: Number of arguments for function degrees doesn't match: passed 2, should be 1: In scope SELECT degrees(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT degrees(NULL, NULL);) 2025.09.09 15:08:09.010748 [ 20345 ] {ace59c79-7ca1-4c8e-9afc-6e3252b8dab8} TCPHandler: Code: 42. DB::Exception: Number of arguments for function degrees doesn't match: passed 2, should be 1: In scope SELECT degrees(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:08:09.080608 [ 20345 ] {ba459840-f4aa-427a-9c12-eec34f8e573b} executeQuery: Code: 42. DB::Exception: Incorrect number of arguments for aggregate function deltaSum. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT deltaSum(NULL, NULL);) 2025.09.09 15:08:09.090927 [ 20345 ] {ba459840-f4aa-427a-9c12-eec34f8e573b} TCPHandler: Code: 42. DB::Exception: Incorrect number of arguments for aggregate function deltaSum. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:08:09.163344 [ 20345 ] {60f7e458-b9a7-4d24-8f35-45feb39b8e94} executeQuery: Code: 43. DB::Exception: Illegal type Nullable(Nothing) of argument for aggregate function deltaSumTimestamp, must be Int, Float, Date, DateTime. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT deltaSumTimestamp(NULL, NULL);) 2025.09.09 15:08:09.166289 [ 20345 ] {60f7e458-b9a7-4d24-8f35-45feb39b8e94} TCPHandler: Code: 43. DB::Exception: Illegal type Nullable(Nothing) of argument for aggregate function deltaSumTimestamp, must be Int, Float, Date, DateTime. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.09.09 15:08:09.223856 [ 20345 ] {9c2139f8-ff33-4b96-a869-f508f932893c} executeQuery: Code: 42. DB::Exception: Number of arguments for function demangle doesn't match: passed 2, should be 1: In scope SELECT demangle(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT demangle(NULL, NULL);) 2025.09.09 15:08:09.232865 [ 20345 ] {9c2139f8-ff33-4b96-a869-f508f932893c} TCPHandler: Code: 42. DB::Exception: Number of arguments for function demangle doesn't match: passed 2, should be 1: In scope SELECT demangle(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:08:09.396454 [ 20345 ] {3561b0d9-5cf7-4cb9-a9fd-6e3a48221f50} executeQuery: Code: 36. DB::Exception: The function 'denseRank' can only be used as a window function, not as an aggregate function: While executing AggregatingTransform. (BAD_ARGUMENTS) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT denseRank(NULL, NULL);) 2025.09.09 15:08:09.409850 [ 20345 ] {3561b0d9-5cf7-4cb9-a9fd-6e3a48221f50} TCPHandler: Code: 36. DB::Exception: The function 'denseRank' can only be used as a window function, not as an aggregate function: While executing AggregatingTransform. (BAD_ARGUMENTS) 2025.09.09 15:08:09.432865 [ 20882 ] {fa00e92a-6c10-46cb-9a89-a277a08b79fa} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=790, jobs=739). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:58562) (comment: 01244_optimize_distributed_group_by_sharding_key.sql) (in query: select 'GROUP BY number distributed_group_by_no_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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af872f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af7b2d1 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af7c3f3 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d36920d 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000002d369e5f 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processOrdinaryQuery() @ 0x000000002d18af7b 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d17644a 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 15. asan_thread_start(void*) @ 0x000000000aa43059 16. ? @ 0x00007f35aab92ac3 17. ? @ 0x00007f35aac24850 2025.09.09 15:08:09.435308 [ 20882 ] {fa00e92a-6c10-46cb-9a89-a277a08b79fa} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=790, 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af872f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af7b2d1 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af7c3f3 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d36920d 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000002d369e5f 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processOrdinaryQuery() @ 0x000000002d18af7b 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d17644a 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 15. asan_thread_start(void*) @ 0x000000000aa43059 16. ? @ 0x00007f35aab92ac3 17. ? @ 0x00007f35aac24850 2025.09.09 15:08:09.546455 [ 20345 ] {0390d8f4-e19a-46b1-afa8-918572f72747} executeQuery: Code: 36. DB::Exception: The function 'denseRank' can only be used as a window function, not as an aggregate function: While executing AggregatingTransform. (BAD_ARGUMENTS) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT dense_rank(NULL, NULL);) 2025.09.09 15:08:09.549611 [ 20345 ] {0390d8f4-e19a-46b1-afa8-918572f72747} TCPHandler: Code: 36. DB::Exception: The function 'denseRank' can only be used as a window function, not as an aggregate function: While executing AggregatingTransform. (BAD_ARGUMENTS) 2025.09.09 15:08:09.589637 [ 2855 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:08:09.668978 [ 20345 ] {e1f225e0-3d66-498e-a6cd-55007ed398be} executeQuery: Code: 344. DB::Exception: Natural language processing function 'detectCharset' is experimental. Set `allow_experimental_nlp_functions` setting to enable it. (SUPPORT_IS_DISABLED) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT detectCharset(NULL, NULL);) 2025.09.09 15:08:09.673398 [ 20345 ] {e1f225e0-3d66-498e-a6cd-55007ed398be} TCPHandler: Code: 344. DB::Exception: Natural language processing function 'detectCharset' is experimental. Set `allow_experimental_nlp_functions` setting to enable it. (SUPPORT_IS_DISABLED) 2025.09.09 15:08:09.710815 [ 20345 ] {17f9ac19-6d15-4e95-bc21-51587564e078} executeQuery: Code: 344. DB::Exception: Natural language processing function 'detectLanguage' is experimental. Set `allow_experimental_nlp_functions` setting to enable it. (SUPPORT_IS_DISABLED) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT detectLanguage(NULL, NULL);) 2025.09.09 15:08:09.715223 [ 20345 ] {17f9ac19-6d15-4e95-bc21-51587564e078} TCPHandler: Code: 344. DB::Exception: Natural language processing function 'detectLanguage' is experimental. Set `allow_experimental_nlp_functions` setting to enable it. (SUPPORT_IS_DISABLED) 2025.09.09 15:08:09.792876 [ 20345 ] {db8ec1b5-a836-4bba-b646-801747a2334e} executeQuery: Code: 344. DB::Exception: Natural language processing function 'detectLanguageMixed' is experimental. Set `allow_experimental_nlp_functions` setting to enable it. (SUPPORT_IS_DISABLED) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT detectLanguageMixed(NULL, NULL);) 2025.09.09 15:08:09.799819 [ 20345 ] {db8ec1b5-a836-4bba-b646-801747a2334e} TCPHandler: Code: 344. DB::Exception: Natural language processing function 'detectLanguageMixed' is experimental. Set `allow_experimental_nlp_functions` setting to enable it. (SUPPORT_IS_DISABLED) 2025.09.09 15:08:09.879689 [ 20345 ] {c440fbdd-3a32-4e8f-85fc-ccc98735ed40} executeQuery: Code: 344. DB::Exception: Natural language processing function 'detectLanguageUnknown' is experimental. Set `allow_experimental_nlp_functions` setting to enable it. (SUPPORT_IS_DISABLED) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT detectLanguageUnknown(NULL, NULL);) 2025.09.09 15:08:09.883834 [ 20345 ] {c440fbdd-3a32-4e8f-85fc-ccc98735ed40} TCPHandler: Code: 344. DB::Exception: Natural language processing function 'detectLanguageUnknown' is experimental. Set `allow_experimental_nlp_functions` setting to enable it. (SUPPORT_IS_DISABLED) 2025.09.09 15:08:09.972563 [ 2951 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:08:09.972936 [ 2941 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:08:09.992668 [ 2929 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:08:10.050280 [ 20345 ] {8899d679-8334-43ae-a6a2-c1ab4b866e01} executeQuery: Code: 344. DB::Exception: Natural language processing function 'detectProgrammingLanguage' is experimental. Set `allow_experimental_nlp_functions` setting to enable it. (SUPPORT_IS_DISABLED) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT detectProgrammingLanguage(NULL, NULL);) 2025.09.09 15:08:10.056972 [ 20345 ] {8899d679-8334-43ae-a6a2-c1ab4b866e01} TCPHandler: Code: 344. DB::Exception: Natural language processing function 'detectProgrammingLanguage' is experimental. Set `allow_experimental_nlp_functions` setting to enable it. (SUPPORT_IS_DISABLED) 2025.09.09 15:08:10.202688 [ 20345 ] {7752f12b-5e59-4461-ad19-3d812443a420} executeQuery: Code: 344. DB::Exception: Natural language processing function 'detectTonality' is experimental. Set `allow_experimental_nlp_functions` setting to enable it. (SUPPORT_IS_DISABLED) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT detectTonality(NULL, NULL);) 2025.09.09 15:08:10.207281 [ 20345 ] {7752f12b-5e59-4461-ad19-3d812443a420} TCPHandler: Code: 344. DB::Exception: Natural language processing function 'detectTonality' is experimental. Set `allow_experimental_nlp_functions` setting to enable it. (SUPPORT_IS_DISABLED) 2025.09.09 15:08:10.252177 [ 20345 ] {50d89cdb-64cd-47f3-9955-ddb2bfb0688e} executeQuery: Code: 42. DB::Exception: Wrong argument count for function dictGet: In scope SELECT dictGet(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT dictGet(NULL, NULL);) 2025.09.09 15:08:10.260515 [ 20345 ] {50d89cdb-64cd-47f3-9955-ddb2bfb0688e} TCPHandler: Code: 42. DB::Exception: Wrong argument count for function dictGet: In scope SELECT dictGet(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:08:10.340049 [ 20345 ] {f8192808-2050-4ebb-85be-fc65a7cf4388} executeQuery: Code: 42. DB::Exception: Wrong argument count for function dictGetAll: In scope SELECT dictGetAll(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT dictGetAll(NULL, NULL);) 2025.09.09 15:08:10.347295 [ 20345 ] {f8192808-2050-4ebb-85be-fc65a7cf4388} TCPHandler: Code: 42. DB::Exception: Wrong argument count for function dictGetAll: In scope SELECT dictGetAll(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:08:10.415034 [ 20345 ] {99a2998f-400e-4633-af8c-157bb218f18c} executeQuery: Code: 1. DB::Exception: Expected const String column: In scope SELECT dictGetChildren(NULL, NULL). (UNSUPPORTED_METHOD) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT dictGetChildren(NULL, NULL);) 2025.09.09 15:08:10.419023 [ 20345 ] {99a2998f-400e-4633-af8c-157bb218f18c} TCPHandler: Code: 1. DB::Exception: Expected const String column: In scope SELECT dictGetChildren(NULL, NULL). (UNSUPPORTED_METHOD) 2025.09.09 15:08:10.511660 [ 20345 ] {3724ac70-522a-48be-b4da-08ab6e074f2b} executeQuery: Code: 42. DB::Exception: Number of arguments for function dictGetDate doesn't match: the function requires more arguments: In scope SELECT dictGetDate(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT dictGetDate(NULL, NULL);) 2025.09.09 15:08:10.526286 [ 20345 ] {3724ac70-522a-48be-b4da-08ab6e074f2b} TCPHandler: Code: 42. DB::Exception: Number of arguments for function dictGetDate doesn't match: the function requires more arguments: In scope SELECT dictGetDate(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:08:10.578896 [ 20345 ] {5583caf3-9428-40df-973c-ce230699ada4} executeQuery: Code: 42. DB::Exception: Number of arguments for function dictGetDateOrDefault doesn't match: the function requires more arguments: In scope SELECT dictGetDateOrDefault(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT dictGetDateOrDefault(NULL, NULL);) 2025.09.09 15:08:10.582076 [ 20345 ] {5583caf3-9428-40df-973c-ce230699ada4} TCPHandler: Code: 42. DB::Exception: Number of arguments for function dictGetDateOrDefault doesn't match: the function requires more arguments: In scope SELECT dictGetDateOrDefault(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:08:10.591308 [ 2957 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:08:10.620869 [ 20345 ] {54d99d61-43e4-4d87-92e3-7ff62c814fdc} executeQuery: Code: 42. DB::Exception: Number of arguments for function dictGetDateTime doesn't match: the function requires more arguments: In scope SELECT dictGetDateTime(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT dictGetDateTime(NULL, NULL);) 2025.09.09 15:08:10.624440 [ 20345 ] {54d99d61-43e4-4d87-92e3-7ff62c814fdc} TCPHandler: Code: 42. DB::Exception: Number of arguments for function dictGetDateTime doesn't match: the function requires more arguments: In scope SELECT dictGetDateTime(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:08:10.685979 [ 20345 ] {e0d0b272-23e7-4010-bc0c-d91d26558311} executeQuery: Code: 42. DB::Exception: Number of arguments for function dictGetDateTimeOrDefault doesn't match: the function requires more arguments: In scope SELECT dictGetDateTimeOrDefault(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT dictGetDateTimeOrDefault(NULL, NULL);) 2025.09.09 15:08:10.689516 [ 20345 ] {e0d0b272-23e7-4010-bc0c-d91d26558311} TCPHandler: Code: 42. DB::Exception: Number of arguments for function dictGetDateTimeOrDefault doesn't match: the function requires more arguments: In scope SELECT dictGetDateTimeOrDefault(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:08:10.801818 [ 20345 ] {ebf08b8f-5c22-4fb1-9342-be9c59375192} executeQuery: Code: 1. DB::Exception: Expected const String column: In scope SELECT dictGetDescendants(NULL, NULL). (UNSUPPORTED_METHOD) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT dictGetDescendants(NULL, NULL);) 2025.09.09 15:08:10.805789 [ 20345 ] {ebf08b8f-5c22-4fb1-9342-be9c59375192} TCPHandler: Code: 1. DB::Exception: Expected const String column: In scope SELECT dictGetDescendants(NULL, NULL). (UNSUPPORTED_METHOD) 2025.09.09 15:08:10.849163 [ 20351 ] {4e7b3b93-5557-4394-aaa0-cfc890bf8e4b} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=790, jobs=740). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:46410) (comment: 00653_running_difference.sql) (in query: select '--Date Difference--';), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af872f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af7b2d1 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af7c3f3 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d36920d 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000002d369e5f 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processOrdinaryQuery() @ 0x000000002d18af7b 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d17644a 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 15. asan_thread_start(void*) @ 0x000000000aa43059 16. ? @ 0x00007f35aab92ac3 17. ? @ 0x00007f35aac24850 2025.09.09 15:08:10.855568 [ 20345 ] {8b3fed12-77f2-40ae-867f-d85e96076681} executeQuery: Code: 42. DB::Exception: Number of arguments for function dictGetFloat32 doesn't match: the function requires more arguments: In scope SELECT dictGetFloat32(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT dictGetFloat32(NULL, NULL);) 2025.09.09 15:08:10.858884 [ 20345 ] {8b3fed12-77f2-40ae-867f-d85e96076681} TCPHandler: Code: 42. DB::Exception: Number of arguments for function dictGetFloat32 doesn't match: the function requires more arguments: In scope SELECT dictGetFloat32(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:08:10.866026 [ 20351 ] {4e7b3b93-5557-4394-aaa0-cfc890bf8e4b} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=790, jobs=740). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af872f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af7b2d1 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af7c3f3 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d36920d 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000002d369e5f 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processOrdinaryQuery() @ 0x000000002d18af7b 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d17644a 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 15. asan_thread_start(void*) @ 0x000000000aa43059 16. ? @ 0x00007f35aab92ac3 17. ? @ 0x00007f35aac24850 2025.09.09 15:08:10.954247 [ 20345 ] {9b91bb3e-573d-4c72-a9e7-7e4c13aee06c} executeQuery: Code: 42. DB::Exception: Number of arguments for function dictGetFloat32OrDefault doesn't match: the function requires more arguments: In scope SELECT dictGetFloat32OrDefault(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT dictGetFloat32OrDefault(NULL, NULL);) 2025.09.09 15:08:10.957234 [ 20345 ] {9b91bb3e-573d-4c72-a9e7-7e4c13aee06c} TCPHandler: Code: 42. DB::Exception: Number of arguments for function dictGetFloat32OrDefault doesn't match: the function requires more arguments: In scope SELECT dictGetFloat32OrDefault(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:08:10.974817 [ 2998 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:08:10.994890 [ 2992 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:08:10.997164 [ 20345 ] {acc265cc-33b8-4fcc-a712-a22db1ac5912} executeQuery: Code: 42. DB::Exception: Number of arguments for function dictGetFloat64 doesn't match: the function requires more arguments: In scope SELECT dictGetFloat64(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT dictGetFloat64(NULL, NULL);) 2025.09.09 15:08:11.003516 [ 20345 ] {acc265cc-33b8-4fcc-a712-a22db1ac5912} TCPHandler: Code: 42. DB::Exception: Number of arguments for function dictGetFloat64 doesn't match: the function requires more arguments: In scope SELECT dictGetFloat64(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:08:11.026722 [ 2997 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:08:11.163395 [ 20345 ] {19c40530-1582-4677-8618-7cbf8db0ae12} executeQuery: Code: 42. DB::Exception: Number of arguments for function dictGetFloat64OrDefault doesn't match: the function requires more arguments: In scope SELECT dictGetFloat64OrDefault(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT dictGetFloat64OrDefault(NULL, NULL);) 2025.09.09 15:08:11.165362 [ 20345 ] {19c40530-1582-4677-8618-7cbf8db0ae12} TCPHandler: Code: 42. DB::Exception: Number of arguments for function dictGetFloat64OrDefault doesn't match: the function requires more arguments: In scope SELECT dictGetFloat64OrDefault(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:08:11.282477 [ 20345 ] {172a56d8-c42f-423a-bef1-631d4ee00992} executeQuery: Code: 42. DB::Exception: Number of arguments for function dictGetIPv4 doesn't match: the function requires more arguments: In scope SELECT dictGetIPv4(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT dictGetIPv4(NULL, NULL);) 2025.09.09 15:08:11.287944 [ 20345 ] {172a56d8-c42f-423a-bef1-631d4ee00992} TCPHandler: Code: 42. DB::Exception: Number of arguments for function dictGetIPv4 doesn't match: the function requires more arguments: In scope SELECT dictGetIPv4(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:08:11.458776 [ 20345 ] {bbb1b8af-2708-42b2-8cba-1748983827c5} executeQuery: Code: 42. DB::Exception: Number of arguments for function dictGetIPv4OrDefault doesn't match: the function requires more arguments: In scope SELECT dictGetIPv4OrDefault(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT dictGetIPv4OrDefault(NULL, NULL);) 2025.09.09 15:08:11.469660 [ 20345 ] {bbb1b8af-2708-42b2-8cba-1748983827c5} TCPHandler: Code: 42. DB::Exception: Number of arguments for function dictGetIPv4OrDefault doesn't match: the function requires more arguments: In scope SELECT dictGetIPv4OrDefault(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:08:11.531766 [ 20345 ] {89fa3f29-6151-47fe-a6f7-e2d29ea8e022} executeQuery: Code: 42. DB::Exception: Number of arguments for function dictGetIPv6 doesn't match: the function requires more arguments: In scope SELECT dictGetIPv6(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT dictGetIPv6(NULL, NULL);) 2025.09.09 15:08:11.539594 [ 20345 ] {89fa3f29-6151-47fe-a6f7-e2d29ea8e022} TCPHandler: Code: 42. DB::Exception: Number of arguments for function dictGetIPv6 doesn't match: the function requires more arguments: In scope SELECT dictGetIPv6(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:08:11.594834 [ 3040 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:08:11.735388 [ 20345 ] {f5a3773c-0fcf-4cb3-9f7a-e1f27acae53b} executeQuery: Code: 42. DB::Exception: Number of arguments for function dictGetIPv6OrDefault doesn't match: the function requires more arguments: In scope SELECT dictGetIPv6OrDefault(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT dictGetIPv6OrDefault(NULL, NULL);) 2025.09.09 15:08:11.740085 [ 20345 ] {f5a3773c-0fcf-4cb3-9f7a-e1f27acae53b} TCPHandler: Code: 42. DB::Exception: Number of arguments for function dictGetIPv6OrDefault doesn't match: the function requires more arguments: In scope SELECT dictGetIPv6OrDefault(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:08:11.828807 [ 20345 ] {6c0d75ec-9778-42f9-be44-f071e251df6f} executeQuery: Code: 42. DB::Exception: Number of arguments for function dictGetInt16 doesn't match: the function requires more arguments: In scope SELECT dictGetInt16(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT dictGetInt16(NULL, NULL);) 2025.09.09 15:08:11.846586 [ 20345 ] {6c0d75ec-9778-42f9-be44-f071e251df6f} TCPHandler: Code: 42. DB::Exception: Number of arguments for function dictGetInt16 doesn't match: the function requires more arguments: In scope SELECT dictGetInt16(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:08:11.894465 [ 20345 ] {d6c41c32-dd2f-4477-8512-fc38aa664aa5} executeQuery: Code: 42. DB::Exception: Number of arguments for function dictGetInt16OrDefault doesn't match: the function requires more arguments: In scope SELECT dictGetInt16OrDefault(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT dictGetInt16OrDefault(NULL, NULL);) 2025.09.09 15:08:11.897733 [ 20345 ] {d6c41c32-dd2f-4477-8512-fc38aa664aa5} TCPHandler: Code: 42. DB::Exception: Number of arguments for function dictGetInt16OrDefault doesn't match: the function requires more arguments: In scope SELECT dictGetInt16OrDefault(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:08:11.976418 [ 3070 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:08:11.996613 [ 3096 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:08:12.007443 [ 20345 ] {e91eb219-34ff-4d6a-a1ca-c6c023361aef} executeQuery: Code: 42. DB::Exception: Number of arguments for function dictGetInt32 doesn't match: the function requires more arguments: In scope SELECT dictGetInt32(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT dictGetInt32(NULL, NULL);) 2025.09.09 15:08:12.011560 [ 20345 ] {e91eb219-34ff-4d6a-a1ca-c6c023361aef} TCPHandler: Code: 42. DB::Exception: Number of arguments for function dictGetInt32 doesn't match: the function requires more arguments: In scope SELECT dictGetInt32(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:08:12.028745 [ 3084 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:08:12.115745 [ 20345 ] {166645b7-f85a-4ae7-9109-98c02b511fb0} executeQuery: Code: 42. DB::Exception: Number of arguments for function dictGetInt32OrDefault doesn't match: the function requires more arguments: In scope SELECT dictGetInt32OrDefault(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT dictGetInt32OrDefault(NULL, NULL);) 2025.09.09 15:08:12.122466 [ 20345 ] {166645b7-f85a-4ae7-9109-98c02b511fb0} TCPHandler: Code: 42. DB::Exception: Number of arguments for function dictGetInt32OrDefault doesn't match: the function requires more arguments: In scope SELECT dictGetInt32OrDefault(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:08:12.272604 [ 20345 ] {f08b6bac-f24a-4543-8f0f-f92213f23b82} executeQuery: Code: 42. DB::Exception: Number of arguments for function dictGetInt64 doesn't match: the function requires more arguments: In scope SELECT dictGetInt64(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT dictGetInt64(NULL, NULL);) 2025.09.09 15:08:12.279531 [ 20345 ] {f08b6bac-f24a-4543-8f0f-f92213f23b82} TCPHandler: Code: 42. DB::Exception: Number of arguments for function dictGetInt64 doesn't match: the function requires more arguments: In scope SELECT dictGetInt64(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:08:12.465842 [ 20345 ] {45fd8cb3-2a43-4504-98c1-b1f9808dc8e8} executeQuery: Code: 42. DB::Exception: Number of arguments for function dictGetInt64OrDefault doesn't match: the function requires more arguments: In scope SELECT dictGetInt64OrDefault(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT dictGetInt64OrDefault(NULL, NULL);) 2025.09.09 15:08:12.475989 [ 20345 ] {45fd8cb3-2a43-4504-98c1-b1f9808dc8e8} TCPHandler: Code: 42. DB::Exception: Number of arguments for function dictGetInt64OrDefault doesn't match: the function requires more arguments: In scope SELECT dictGetInt64OrDefault(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:08:12.597003 [ 20345 ] {ac6bda0d-fa51-4f89-9a62-51b5f755c7d0} executeQuery: Code: 42. DB::Exception: Number of arguments for function dictGetInt8 doesn't match: the function requires more arguments: In scope SELECT dictGetInt8(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT dictGetInt8(NULL, NULL);) 2025.09.09 15:08:12.597827 [ 3110 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:08:12.604918 [ 20345 ] {ac6bda0d-fa51-4f89-9a62-51b5f755c7d0} TCPHandler: Code: 42. DB::Exception: Number of arguments for function dictGetInt8 doesn't match: the function requires more arguments: In scope SELECT dictGetInt8(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:08:12.740642 [ 20345 ] {a391c62b-31d6-4bdf-baf1-6d3a797b6f11} executeQuery: Code: 42. DB::Exception: Number of arguments for function dictGetInt8OrDefault doesn't match: the function requires more arguments: In scope SELECT dictGetInt8OrDefault(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT dictGetInt8OrDefault(NULL, NULL);) 2025.09.09 15:08:12.753573 [ 20345 ] {a391c62b-31d6-4bdf-baf1-6d3a797b6f11} TCPHandler: Code: 42. DB::Exception: Number of arguments for function dictGetInt8OrDefault doesn't match: the function requires more arguments: In scope SELECT dictGetInt8OrDefault(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:08:12.867472 [ 20345 ] {bca8c4fc-1714-473a-b29b-d38d1573b71c} executeQuery: Code: 42. DB::Exception: Wrong argument count for function dictGetOrDefault: In scope SELECT dictGetOrDefault(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT dictGetOrDefault(NULL, NULL);) 2025.09.09 15:08:12.871488 [ 20345 ] {bca8c4fc-1714-473a-b29b-d38d1573b71c} TCPHandler: Code: 42. DB::Exception: Wrong argument count for function dictGetOrDefault: In scope SELECT dictGetOrDefault(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:08:12.978949 [ 3165 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:08:12.999275 [ 3162 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:08:13.006765 [ 20345 ] {89f1075c-6a94-4b8e-8fb3-7a89b3eb78ca} executeQuery: Code: 42. DB::Exception: Wrong argument count for function dictGet: In scope SELECT dictGetOrNull(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT dictGetOrNull(NULL, NULL);) 2025.09.09 15:08:13.010654 [ 20345 ] {89f1075c-6a94-4b8e-8fb3-7a89b3eb78ca} TCPHandler: Code: 42. DB::Exception: Wrong argument count for function dictGet: In scope SELECT dictGetOrNull(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:08:13.031097 [ 3188 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:08:13.132724 [ 20345 ] {f626f083-a68f-4f39-940e-9fbddc3e7ef4} executeQuery: Code: 42. DB::Exception: Number of arguments for function dictGetString doesn't match: the function requires more arguments: In scope SELECT dictGetString(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT dictGetString(NULL, NULL);) 2025.09.09 15:08:13.140209 [ 20345 ] {f626f083-a68f-4f39-940e-9fbddc3e7ef4} TCPHandler: Code: 42. DB::Exception: Number of arguments for function dictGetString doesn't match: the function requires more arguments: In scope SELECT dictGetString(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:08:13.209722 [ 20345 ] {9241bd29-1036-4fca-900b-ff1f1252f34f} executeQuery: Code: 42. DB::Exception: Number of arguments for function dictGetStringOrDefault doesn't match: the function requires more arguments: In scope SELECT dictGetStringOrDefault(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT dictGetStringOrDefault(NULL, NULL);) 2025.09.09 15:08:13.213471 [ 20345 ] {9241bd29-1036-4fca-900b-ff1f1252f34f} TCPHandler: Code: 42. DB::Exception: Number of arguments for function dictGetStringOrDefault doesn't match: the function requires more arguments: In scope SELECT dictGetStringOrDefault(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:08:13.296265 [ 20345 ] {bc3404b0-0d0d-4f07-9cc1-87a7934d6bf2} executeQuery: Code: 42. DB::Exception: Number of arguments for function dictGetUInt16 doesn't match: the function requires more arguments: In scope SELECT dictGetUInt16(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT dictGetUInt16(NULL, NULL);) 2025.09.09 15:08:13.306575 [ 20345 ] {bc3404b0-0d0d-4f07-9cc1-87a7934d6bf2} TCPHandler: Code: 42. DB::Exception: Number of arguments for function dictGetUInt16 doesn't match: the function requires more arguments: In scope SELECT dictGetUInt16(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:08:13.483109 [ 20345 ] {d9a0244e-eb79-44a7-ae77-f92749234ca9} executeQuery: Code: 42. DB::Exception: Number of arguments for function dictGetUInt16OrDefault doesn't match: the function requires more arguments: In scope SELECT dictGetUInt16OrDefault(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT dictGetUInt16OrDefault(NULL, NULL);) 2025.09.09 15:08:13.509502 [ 20345 ] {d9a0244e-eb79-44a7-ae77-f92749234ca9} TCPHandler: Code: 42. DB::Exception: Number of arguments for function dictGetUInt16OrDefault doesn't match: the function requires more arguments: In scope SELECT dictGetUInt16OrDefault(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:08:13.566582 [ 20345 ] {8c8255d1-ed2f-4ec8-bda6-bcbc978e728b} executeQuery: Code: 42. DB::Exception: Number of arguments for function dictGetUInt32 doesn't match: the function requires more arguments: In scope SELECT dictGetUInt32(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT dictGetUInt32(NULL, NULL);) 2025.09.09 15:08:13.581200 [ 20345 ] {8c8255d1-ed2f-4ec8-bda6-bcbc978e728b} TCPHandler: Code: 42. DB::Exception: Number of arguments for function dictGetUInt32 doesn't match: the function requires more arguments: In scope SELECT dictGetUInt32(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:08:13.606899 [ 3237 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:08:13.673765 [ 20345 ] {5f4c64cc-7de6-4ec1-829a-8c32ba0012c9} executeQuery: Code: 42. DB::Exception: Number of arguments for function dictGetUInt32OrDefault doesn't match: the function requires more arguments: In scope SELECT dictGetUInt32OrDefault(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT dictGetUInt32OrDefault(NULL, NULL);) 2025.09.09 15:08:13.682815 [ 20345 ] {5f4c64cc-7de6-4ec1-829a-8c32ba0012c9} TCPHandler: Code: 42. DB::Exception: Number of arguments for function dictGetUInt32OrDefault doesn't match: the function requires more arguments: In scope SELECT dictGetUInt32OrDefault(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:08:13.821113 [ 20345 ] {e419be9d-8edb-4049-b0b4-1d9428d71b19} executeQuery: Code: 42. DB::Exception: Number of arguments for function dictGetUInt64 doesn't match: the function requires more arguments: In scope SELECT dictGetUInt64(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT dictGetUInt64(NULL, NULL);) 2025.09.09 15:08:13.824743 [ 20345 ] {e419be9d-8edb-4049-b0b4-1d9428d71b19} TCPHandler: Code: 42. DB::Exception: Number of arguments for function dictGetUInt64 doesn't match: the function requires more arguments: In scope SELECT dictGetUInt64(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:08:13.960218 [ 20345 ] {787b531f-dcbd-4630-a648-8c68e3501e5e} executeQuery: Code: 42. DB::Exception: Number of arguments for function dictGetUInt64OrDefault doesn't match: the function requires more arguments: In scope SELECT dictGetUInt64OrDefault(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT dictGetUInt64OrDefault(NULL, NULL);) 2025.09.09 15:08:13.978455 [ 20345 ] {787b531f-dcbd-4630-a648-8c68e3501e5e} TCPHandler: Code: 42. DB::Exception: Number of arguments for function dictGetUInt64OrDefault doesn't match: the function requires more arguments: In scope SELECT dictGetUInt64OrDefault(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:08:13.985197 [ 3224 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:08:14.010593 [ 2768 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:08:14.033904 [ 2761 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:08:14.079293 [ 20345 ] {c5893b3e-24f4-46fc-82f6-751ee4533980} executeQuery: Code: 42. DB::Exception: Number of arguments for function dictGetUInt8 doesn't match: the function requires more arguments: In scope SELECT dictGetUInt8(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT dictGetUInt8(NULL, NULL);) 2025.09.09 15:08:14.156278 [ 20345 ] {c5893b3e-24f4-46fc-82f6-751ee4533980} TCPHandler: Code: 42. DB::Exception: Number of arguments for function dictGetUInt8 doesn't match: the function requires more arguments: In scope SELECT dictGetUInt8(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:08:14.275464 [ 20345 ] {780e95a3-c3b1-444c-b1f1-a6581a886b01} executeQuery: Code: 42. DB::Exception: Number of arguments for function dictGetUInt8OrDefault doesn't match: the function requires more arguments: In scope SELECT dictGetUInt8OrDefault(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT dictGetUInt8OrDefault(NULL, NULL);) 2025.09.09 15:08:14.290833 [ 20345 ] {780e95a3-c3b1-444c-b1f1-a6581a886b01} TCPHandler: Code: 42. DB::Exception: Number of arguments for function dictGetUInt8OrDefault doesn't match: the function requires more arguments: In scope SELECT dictGetUInt8OrDefault(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:08:14.424762 [ 20345 ] {bb7e987e-eea9-4e86-9c54-d60590d00d21} executeQuery: Code: 42. DB::Exception: Number of arguments for function dictGetUUID doesn't match: the function requires more arguments: In scope SELECT dictGetUUID(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT dictGetUUID(NULL, NULL);) 2025.09.09 15:08:14.428347 [ 20345 ] {bb7e987e-eea9-4e86-9c54-d60590d00d21} TCPHandler: Code: 42. DB::Exception: Number of arguments for function dictGetUUID doesn't match: the function requires more arguments: In scope SELECT dictGetUUID(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:08:14.471790 [ 20345 ] {c3bde3d3-a83e-4ea4-8adf-df32ef1f9824} executeQuery: Code: 42. DB::Exception: Number of arguments for function dictGetUUIDOrDefault doesn't match: the function requires more arguments: In scope SELECT dictGetUUIDOrDefault(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT dictGetUUIDOrDefault(NULL, NULL);) 2025.09.09 15:08:14.477286 [ 20345 ] {c3bde3d3-a83e-4ea4-8adf-df32ef1f9824} TCPHandler: Code: 42. DB::Exception: Number of arguments for function dictGetUUIDOrDefault doesn't match: the function requires more arguments: In scope SELECT dictGetUUIDOrDefault(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:08:14.605971 [ 3326 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {120a6b4f-0f93-4c7b-b7cc-46807ffa23fa::202509_1_155_31}: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=13, jobs=2). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af80b71 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80746 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002c765aab 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:1197: ? @ 0x000000002c7602b8 8. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x000000002c75fc2b 9. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:0: DB::MergeTreeReaderCompact::MergeTreeReaderCompact(std::shared_ptr, DB::NamesAndTypesList, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*, DB::MarkCache*, DB::MarkRanges, DB::MergeTreeReaderSettings, std::map, std::allocator>>, std::function const&, int) @ 0x000000002c7aee03 10. ./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.h:16: DB::MergeTreeReaderCompactSingleBuffer::MergeTreeReaderCompactSingleBuffer&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int&&) @ 0x000000002c5d6d21 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::MergeTreeDataPartCompact::getReader(DB::NamesAndTypesList const&, std::shared_ptr const&, DB::MarkRanges const&, std::unordered_map, std::equal_to, std::allocator>> const&, DB::UncompressedCache*, DB::MarkCache*, std::shared_ptr const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) const @ 0x000000002c5d1037 12. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:169: DB::MergeTreeSequentialSource::MergeTreeSequentialSource(DB::MergeTreeSequentialSourceType, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::vector>, std::optional, bool, bool, bool) @ 0x000000002c80c330 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:35: DB::MergeTreeSequentialSource* std::construct_at[abi:v15007] const&, std::shared_ptr&, std::shared_ptr&, std::vector>&, std::optional, bool, bool&, bool&, DB::MergeTreeSequentialSource*>(DB::MergeTreeSequentialSource*, DB::MergeTreeSequentialSourceType&, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr&, std::shared_ptr&, std::vector>&, std::optional&&, bool&&, bool&, bool&) @ 0x000000002c81320f 14. ./contrib/llvm-project/libcxx/include/__memory/allocator_traits.h:298: DB::createMergeTreeSequentialSource(DB::MergeTreeSequentialSourceType, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::vector>, std::optional, std::shared_ptr>, bool, bool, bool) @ 0x000000002c810812 15. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1136: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::createMergedStream() @ 0x000000002c3dd079 16. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() @ 0x000000002c3d6516 17. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:534: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x000000002c3e2799 18. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::execute() @ 0x000000002c3ef3fe 19. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:0: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000002cc2f4c0 20. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000002c427f28 21. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000002c429675 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7eaf0 23. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001af8a79f 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 26. asan_thread_start(void*) @ 0x000000000aa43059 27. ? @ 0x00007f35aab92ac3 28. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:08:14.608579 [ 2796 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:08:14.643087 [ 20345 ] {9ea6c249-fe13-40b0-94bb-478404b5c121} executeQuery: Code: 42. DB::Exception: Number of arguments for function dictIsIn doesn't match: passed 2, should be 3: In scope SELECT dictIsIn(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT dictIsIn(NULL, NULL);) 2025.09.09 15:08:14.647319 [ 20345 ] {9ea6c249-fe13-40b0-94bb-478404b5c121} TCPHandler: Code: 42. DB::Exception: Number of arguments for function dictIsIn doesn't match: passed 2, should be 3: In scope SELECT dictIsIn(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:08:14.721909 [ 20345 ] {27d42a9d-bc5f-495a-a0ae-9b7d5ce4923a} executeQuery: Code: 42. DB::Exception: Number of arguments for function displayName doesn't match: passed 2, should be 0: In scope SELECT displayName(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT displayName(NULL, NULL);) 2025.09.09 15:08:14.725295 [ 20345 ] {27d42a9d-bc5f-495a-a0ae-9b7d5ce4923a} TCPHandler: Code: 42. DB::Exception: Number of arguments for function displayName doesn't match: passed 2, should be 0: In scope SELECT displayName(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:08:14.987427 [ 2817 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:08:15.014723 [ 2821 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:08:15.035850 [ 2836 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:08:15.511349 [ 20345 ] {fc534dda-228e-462c-b8e2-895fff445659} executeQuery: Code: 42. DB::Exception: Number of arguments for function LpDistance doesn't match: passed 2, should be 3: In scope SELECT distanceLp(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT distanceLp(NULL, NULL);) 2025.09.09 15:08:15.515874 [ 20345 ] {fc534dda-228e-462c-b8e2-895fff445659} TCPHandler: Code: 42. DB::Exception: Number of arguments for function LpDistance doesn't match: passed 2, should be 3: In scope SELECT distanceLp(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:08:15.610392 [ 2899 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:08:15.917039 [ 20345 ] {4605519c-ce4b-453a-81b6-e69e897e3527} executeQuery: Code: 42. DB::Exception: Number of arguments for function domain doesn't match: passed 2, should be 1: In scope SELECT domain(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT domain(NULL, NULL);) 2025.09.09 15:08:15.919279 [ 20345 ] {4605519c-ce4b-453a-81b6-e69e897e3527} TCPHandler: Code: 42. DB::Exception: Number of arguments for function domain doesn't match: passed 2, should be 1: In scope SELECT domain(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:08:15.974396 [ 20345 ] {83790207-4b45-483a-82be-1b8a893ce5ae} executeQuery: Code: 42. DB::Exception: Number of arguments for function domainRFC doesn't match: passed 2, should be 1: In scope SELECT domainRFC(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT domainRFC(NULL, NULL);) 2025.09.09 15:08:15.985355 [ 20345 ] {83790207-4b45-483a-82be-1b8a893ce5ae} TCPHandler: Code: 42. DB::Exception: Number of arguments for function domainRFC doesn't match: passed 2, should be 1: In scope SELECT domainRFC(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:08:15.989441 [ 2919 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:08:16.016630 [ 2881 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:08:16.037516 [ 2887 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:08:16.050307 [ 20345 ] {2207bb52-2f74-496d-84cf-3521026fc3ce} executeQuery: Code: 42. DB::Exception: Number of arguments for function domainWithoutWWW doesn't match: passed 2, should be 1: In scope SELECT domainWithoutWWW(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT domainWithoutWWW(NULL, NULL);) 2025.09.09 15:08:16.059852 [ 20345 ] {2207bb52-2f74-496d-84cf-3521026fc3ce} TCPHandler: Code: 42. DB::Exception: Number of arguments for function domainWithoutWWW doesn't match: passed 2, should be 1: In scope SELECT domainWithoutWWW(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:08:16.214123 [ 20345 ] {dfab54bc-adbc-46da-8b73-e497beaadd9a} executeQuery: Code: 42. DB::Exception: Number of arguments for function domainWithoutWWWRFC doesn't match: passed 2, should be 1: In scope SELECT domainWithoutWWWRFC(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT domainWithoutWWWRFC(NULL, NULL);) 2025.09.09 15:08:16.216190 [ 20345 ] {dfab54bc-adbc-46da-8b73-e497beaadd9a} TCPHandler: Code: 42. DB::Exception: Number of arguments for function domainWithoutWWWRFC doesn't match: passed 2, should be 1: In scope SELECT domainWithoutWWWRFC(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:08:16.289341 [ 20345 ] {5b9ca37c-8c35-4d59-83c3-6492fd8424d8} executeQuery: Code: 42. DB::Exception: Number of arguments for function dumpColumnStructure doesn't match: passed 2, should be 1: In scope SELECT dumpColumnStructure(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT dumpColumnStructure(NULL, NULL);) 2025.09.09 15:08:16.292581 [ 20345 ] {5b9ca37c-8c35-4d59-83c3-6492fd8424d8} TCPHandler: Code: 42. DB::Exception: Number of arguments for function dumpColumnStructure doesn't match: passed 2, should be 1: In scope SELECT dumpColumnStructure(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:08:16.324604 [ 20345 ] {64d3fb14-1d18-46c8-b642-f078a2dffd47} executeQuery: Code: 43. DB::Exception: First argument for function dynamicElement must be Variant or Array of Variant. Actual Nullable(Nothing): In scope SELECT dynamicElement(NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT dynamicElement(NULL, NULL);) 2025.09.09 15:08:16.335059 [ 20345 ] {64d3fb14-1d18-46c8-b642-f078a2dffd47} TCPHandler: Code: 43. DB::Exception: First argument for function dynamicElement must be Variant or Array of Variant. Actual Nullable(Nothing): In scope SELECT dynamicElement(NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.09.09 15:08:16.395687 [ 20345 ] {6a7c1693-2dfd-4a8b-ad1d-722ece86d051} executeQuery: Code: 42. DB::Exception: Number of arguments for function dynamicType doesn't match: passed 2, should be 1: In scope SELECT dynamicType(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT dynamicType(NULL, NULL);) 2025.09.09 15:08:16.400739 [ 20345 ] {6a7c1693-2dfd-4a8b-ad1d-722ece86d051} TCPHandler: Code: 42. DB::Exception: Number of arguments for function dynamicType doesn't match: passed 2, should be 1: In scope SELECT dynamicType(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:08:16.463646 [ 20345 ] {c49de08f-b552-4803-829e-7e6dd52a7a3d} executeQuery: Code: 42. DB::Exception: Number of arguments for function e doesn't match: passed 2, should be 0: In scope SELECT e(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT e(NULL, NULL);) 2025.09.09 15:08:16.466680 [ 20345 ] {c49de08f-b552-4803-829e-7e6dd52a7a3d} TCPHandler: Code: 42. DB::Exception: Number of arguments for function e doesn't match: passed 2, should be 0: In scope SELECT e(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:08:16.612459 [ 2987 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:08:16.779085 [ 20345 ] {069c23f2-3d32-46ce-9797-f5db8d5f18d1} executeQuery: Code: 42. DB::Exception: Number of arguments for function empty doesn't match: passed 2, should be 1: In scope SELECT empty(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT empty(NULL, NULL);) 2025.09.09 15:08:16.783639 [ 20345 ] {069c23f2-3d32-46ce-9797-f5db8d5f18d1} TCPHandler: Code: 42. DB::Exception: Number of arguments for function empty doesn't match: passed 2, should be 1: In scope SELECT empty(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:08:16.897485 [ 20345 ] {7b26359f-1d50-4def-8105-02014b8e9d5a} executeQuery: Code: 42. DB::Exception: Number of arguments for function emptyArrayDate doesn't match: passed 2, should be 0: In scope SELECT emptyArrayDate(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT emptyArrayDate(NULL, NULL);) 2025.09.09 15:08:16.903412 [ 20345 ] {7b26359f-1d50-4def-8105-02014b8e9d5a} TCPHandler: Code: 42. DB::Exception: Number of arguments for function emptyArrayDate doesn't match: passed 2, should be 0: In scope SELECT emptyArrayDate(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:08:16.974566 [ 20345 ] {1841ab1c-ed7d-44a3-a1a1-ca70f05b4e57} executeQuery: Code: 42. DB::Exception: Number of arguments for function emptyArrayDateTime doesn't match: passed 2, should be 0: In scope SELECT emptyArrayDateTime(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT emptyArrayDateTime(NULL, NULL);) 2025.09.09 15:08:16.980958 [ 20345 ] {1841ab1c-ed7d-44a3-a1a1-ca70f05b4e57} TCPHandler: Code: 42. DB::Exception: Number of arguments for function emptyArrayDateTime doesn't match: passed 2, should be 0: In scope SELECT emptyArrayDateTime(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:08:16.992482 [ 3001 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:08:17.019570 [ 3010 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:08:17.044282 [ 3016 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:08:17.071444 [ 20345 ] {3969d520-440a-475f-b8e3-0e74c6e7cb0f} executeQuery: Code: 42. DB::Exception: Number of arguments for function emptyArrayFloat32 doesn't match: passed 2, should be 0: In scope SELECT emptyArrayFloat32(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT emptyArrayFloat32(NULL, NULL);) 2025.09.09 15:08:17.101673 [ 20345 ] {3969d520-440a-475f-b8e3-0e74c6e7cb0f} TCPHandler: Code: 42. DB::Exception: Number of arguments for function emptyArrayFloat32 doesn't match: passed 2, should be 0: In scope SELECT emptyArrayFloat32(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:08:17.194822 [ 20345 ] {ce92a1fa-c96f-4477-a489-92deb7a8bc3f} executeQuery: Code: 42. DB::Exception: Number of arguments for function emptyArrayFloat64 doesn't match: passed 2, should be 0: In scope SELECT emptyArrayFloat64(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT emptyArrayFloat64(NULL, NULL);) 2025.09.09 15:08:17.202241 [ 20345 ] {ce92a1fa-c96f-4477-a489-92deb7a8bc3f} TCPHandler: Code: 42. DB::Exception: Number of arguments for function emptyArrayFloat64 doesn't match: passed 2, should be 0: In scope SELECT emptyArrayFloat64(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:08:17.252004 [ 20345 ] {dd998d25-d6c8-4296-995f-fad1ccacbdcb} executeQuery: Code: 42. DB::Exception: Number of arguments for function emptyArrayInt16 doesn't match: passed 2, should be 0: In scope SELECT emptyArrayInt16(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT emptyArrayInt16(NULL, NULL);) 2025.09.09 15:08:17.260567 [ 20345 ] {dd998d25-d6c8-4296-995f-fad1ccacbdcb} TCPHandler: Code: 42. DB::Exception: Number of arguments for function emptyArrayInt16 doesn't match: passed 2, should be 0: In scope SELECT emptyArrayInt16(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:08:17.307984 [ 20345 ] {4f272fc3-69c3-4145-bb92-d08f9002011b} executeQuery: Code: 42. DB::Exception: Number of arguments for function emptyArrayInt32 doesn't match: passed 2, should be 0: In scope SELECT emptyArrayInt32(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT emptyArrayInt32(NULL, NULL);) 2025.09.09 15:08:17.310653 [ 20345 ] {4f272fc3-69c3-4145-bb92-d08f9002011b} TCPHandler: Code: 42. DB::Exception: Number of arguments for function emptyArrayInt32 doesn't match: passed 2, should be 0: In scope SELECT emptyArrayInt32(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:08:17.344498 [ 20345 ] {ddee1855-8b26-4f7a-a2a1-422a13f1974b} executeQuery: Code: 42. DB::Exception: Number of arguments for function emptyArrayInt64 doesn't match: passed 2, should be 0: In scope SELECT emptyArrayInt64(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT emptyArrayInt64(NULL, NULL);) 2025.09.09 15:08:17.346618 [ 20345 ] {ddee1855-8b26-4f7a-a2a1-422a13f1974b} TCPHandler: Code: 42. DB::Exception: Number of arguments for function emptyArrayInt64 doesn't match: passed 2, should be 0: In scope SELECT emptyArrayInt64(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:08:17.392500 [ 20345 ] {69f5b536-8918-4fec-8a80-e3c00b9f77d8} executeQuery: Code: 42. DB::Exception: Number of arguments for function emptyArrayInt8 doesn't match: passed 2, should be 0: In scope SELECT emptyArrayInt8(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT emptyArrayInt8(NULL, NULL);) 2025.09.09 15:08:17.395377 [ 20345 ] {69f5b536-8918-4fec-8a80-e3c00b9f77d8} TCPHandler: Code: 42. DB::Exception: Number of arguments for function emptyArrayInt8 doesn't match: passed 2, should be 0: In scope SELECT emptyArrayInt8(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:08:17.436855 [ 20345 ] {93e4960b-b74a-428a-9f84-5e0f400b8b51} executeQuery: Code: 42. DB::Exception: Number of arguments for function emptyArrayString doesn't match: passed 2, should be 0: In scope SELECT emptyArrayString(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT emptyArrayString(NULL, NULL);) 2025.09.09 15:08:17.440292 [ 20345 ] {93e4960b-b74a-428a-9f84-5e0f400b8b51} TCPHandler: Code: 42. DB::Exception: Number of arguments for function emptyArrayString doesn't match: passed 2, should be 0: In scope SELECT emptyArrayString(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:08:17.500508 [ 20345 ] {3bca6bdf-c6ba-4876-bd91-2256d886fcb8} executeQuery: Code: 42. DB::Exception: Number of arguments for function emptyArrayToSingle doesn't match: passed 2, should be 1: In scope SELECT emptyArrayToSingle(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT emptyArrayToSingle(NULL, NULL);) 2025.09.09 15:08:17.504044 [ 20345 ] {3bca6bdf-c6ba-4876-bd91-2256d886fcb8} TCPHandler: Code: 42. DB::Exception: Number of arguments for function emptyArrayToSingle doesn't match: passed 2, should be 1: In scope SELECT emptyArrayToSingle(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:08:17.543394 [ 20345 ] {b49cbc31-6aed-4875-a8b8-3a483b851287} executeQuery: Code: 42. DB::Exception: Number of arguments for function emptyArrayUInt16 doesn't match: passed 2, should be 0: In scope SELECT emptyArrayUInt16(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT emptyArrayUInt16(NULL, NULL);) 2025.09.09 15:08:17.545559 [ 20345 ] {b49cbc31-6aed-4875-a8b8-3a483b851287} TCPHandler: Code: 42. DB::Exception: Number of arguments for function emptyArrayUInt16 doesn't match: passed 2, should be 0: In scope SELECT emptyArrayUInt16(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:08:17.577373 [ 20345 ] {01f200f1-b788-4d83-b66e-92be91c1210d} executeQuery: Code: 42. DB::Exception: Number of arguments for function emptyArrayUInt32 doesn't match: passed 2, should be 0: In scope SELECT emptyArrayUInt32(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT emptyArrayUInt32(NULL, NULL);) 2025.09.09 15:08:17.582028 [ 20345 ] {01f200f1-b788-4d83-b66e-92be91c1210d} TCPHandler: Code: 42. DB::Exception: Number of arguments for function emptyArrayUInt32 doesn't match: passed 2, should be 0: In scope SELECT emptyArrayUInt32(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:08:17.615640 [ 3082 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:08:17.741261 [ 20345 ] {3bb7f154-a963-44d1-ac70-1d403c1c8a70} executeQuery: Code: 42. DB::Exception: Number of arguments for function emptyArrayUInt64 doesn't match: passed 2, should be 0: In scope SELECT emptyArrayUInt64(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT emptyArrayUInt64(NULL, NULL);) 2025.09.09 15:08:17.746445 [ 20345 ] {3bb7f154-a963-44d1-ac70-1d403c1c8a70} TCPHandler: Code: 42. DB::Exception: Number of arguments for function emptyArrayUInt64 doesn't match: passed 2, should be 0: In scope SELECT emptyArrayUInt64(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:08:17.803946 [ 20345 ] {b59d704a-243d-48f4-9ec9-ed1a08558d4c} executeQuery: Code: 42. DB::Exception: Number of arguments for function emptyArrayUInt8 doesn't match: passed 2, should be 0: In scope SELECT emptyArrayUInt8(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT emptyArrayUInt8(NULL, NULL);) 2025.09.09 15:08:17.808105 [ 20345 ] {b59d704a-243d-48f4-9ec9-ed1a08558d4c} TCPHandler: Code: 42. DB::Exception: Number of arguments for function emptyArrayUInt8 doesn't match: passed 2, should be 0: In scope SELECT emptyArrayUInt8(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:08:17.877309 [ 20345 ] {4d58ba1d-14ee-4c34-9007-b4ebe1156a0b} executeQuery: Code: 42. DB::Exception: Number of arguments for function enabledProfiles doesn't match: passed 2, should be 0: In scope SELECT enabledProfiles(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT enabledProfiles(NULL, NULL);) 2025.09.09 15:08:17.883508 [ 20345 ] {4d58ba1d-14ee-4c34-9007-b4ebe1156a0b} TCPHandler: Code: 42. DB::Exception: Number of arguments for function enabledProfiles doesn't match: passed 2, should be 0: In scope SELECT enabledProfiles(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:08:17.972949 [ 20345 ] {9a44510a-b93c-4701-b2e1-4487dfdb9ff8} executeQuery: Code: 42. DB::Exception: Number of arguments for function enabledRoles doesn't match: passed 2, should be 0: In scope SELECT enabledRoles(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT enabledRoles(NULL, NULL);) 2025.09.09 15:08:17.977705 [ 20345 ] {9a44510a-b93c-4701-b2e1-4487dfdb9ff8} TCPHandler: Code: 42. DB::Exception: Number of arguments for function enabledRoles doesn't match: passed 2, should be 0: In scope SELECT enabledRoles(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:08:17.995717 [ 3119 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:08:18.023243 [ 3115 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:08:18.047505 [ 3135 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:08:18.088669 [ 20345 ] {8a922891-7a5a-4c04-b3d8-641631e74ada} executeQuery: Code: 42. DB::Exception: Number of arguments for function encodeURLComponent doesn't match: passed 2, should be 1: In scope SELECT encodeURLComponent(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT encodeURLComponent(NULL, NULL);) 2025.09.09 15:08:18.115632 [ 20345 ] {8a922891-7a5a-4c04-b3d8-641631e74ada} TCPHandler: Code: 42. DB::Exception: Number of arguments for function encodeURLComponent doesn't match: passed 2, should be 1: In scope SELECT encodeURLComponent(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:08:18.183712 [ 20345 ] {28b94c78-34ad-47d0-b332-3d179fd0b42a} executeQuery: Code: 42. DB::Exception: Number of arguments for function encodeURLFormComponent doesn't match: passed 2, should be 1: In scope SELECT encodeURLFormComponent(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT encodeURLFormComponent(NULL, NULL);) 2025.09.09 15:08:18.186939 [ 20345 ] {28b94c78-34ad-47d0-b332-3d179fd0b42a} TCPHandler: Code: 42. DB::Exception: Number of arguments for function encodeURLFormComponent doesn't match: passed 2, should be 1: In scope SELECT encodeURLFormComponent(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:08:18.230661 [ 20345 ] {7adbe5ce-72cd-4c78-b7da-95ea6bced256} executeQuery: Code: 42. DB::Exception: Number of arguments for function encodeXMLComponent doesn't match: passed 2, should be 1: In scope SELECT encodeXMLComponent(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT encodeXMLComponent(NULL, NULL);) 2025.09.09 15:08:18.234147 [ 20345 ] {7adbe5ce-72cd-4c78-b7da-95ea6bced256} TCPHandler: Code: 42. DB::Exception: Number of arguments for function encodeXMLComponent doesn't match: passed 2, should be 1: In scope SELECT encodeXMLComponent(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:08:18.617770 [ 3187 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:08:18.802878 [ 20345 ] {aaeea247-801f-4b0e-95e4-33b0fc13cb9d} executeQuery: Code: 42. DB::Exception: Number of arguments for function erf doesn't match: passed 2, should be 1: In scope SELECT erf(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT erf(NULL, NULL);) 2025.09.09 15:08:18.806071 [ 20345 ] {aaeea247-801f-4b0e-95e4-33b0fc13cb9d} TCPHandler: Code: 42. DB::Exception: Number of arguments for function erf doesn't match: passed 2, should be 1: In scope SELECT erf(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:08:18.853881 [ 20345 ] {d3729891-e423-4692-8978-39321e990aa0} executeQuery: Code: 42. DB::Exception: Number of arguments for function erfc doesn't match: passed 2, should be 1: In scope SELECT erfc(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT erfc(NULL, NULL);) 2025.09.09 15:08:18.859893 [ 20345 ] {d3729891-e423-4692-8978-39321e990aa0} TCPHandler: Code: 42. DB::Exception: Number of arguments for function erfc doesn't match: passed 2, should be 1: In scope SELECT erfc(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:08:18.910724 [ 20345 ] {2bd337b6-b391-4e78-8847-97753d5d64a2} executeQuery: Code: 42. DB::Exception: Number of arguments for function errorCodeToName doesn't match: passed 2, should be 1: In scope SELECT errorCodeToName(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT errorCodeToName(NULL, NULL);) 2025.09.09 15:08:18.926339 [ 20345 ] {2bd337b6-b391-4e78-8847-97753d5d64a2} TCPHandler: Code: 42. DB::Exception: Number of arguments for function errorCodeToName doesn't match: passed 2, should be 1: In scope SELECT errorCodeToName(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:08:18.997842 [ 2736 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:08:19.025769 [ 3159 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:08:19.049638 [ 3170 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:08:19.085543 [ 20345 ] {c0aee99f-2807-44b2-9a85-aaf0663ed98a} executeQuery: Code: 42. DB::Exception: Number of arguments for function exp doesn't match: passed 2, should be 1: In scope SELECT exp(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT exp(NULL, NULL);) 2025.09.09 15:08:19.089497 [ 20345 ] {c0aee99f-2807-44b2-9a85-aaf0663ed98a} TCPHandler: Code: 42. DB::Exception: Number of arguments for function exp doesn't match: passed 2, should be 1: In scope SELECT exp(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:08:19.177195 [ 20345 ] {ba096dba-c8d4-4ff5-8b09-31aa3ab4db67} executeQuery: Code: 42. DB::Exception: Number of arguments for function exp10 doesn't match: passed 2, should be 1: In scope SELECT exp10(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT exp10(NULL, NULL);) 2025.09.09 15:08:19.190649 [ 20345 ] {ba096dba-c8d4-4ff5-8b09-31aa3ab4db67} TCPHandler: Code: 42. DB::Exception: Number of arguments for function exp10 doesn't match: passed 2, should be 1: In scope SELECT exp10(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:08:19.271066 [ 20345 ] {8f5aba2d-c408-4853-928d-7b0813952bd8} executeQuery: Code: 42. DB::Exception: Number of arguments for function exp2 doesn't match: passed 2, should be 1: In scope SELECT exp2(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT exp2(NULL, NULL);) 2025.09.09 15:08:19.274833 [ 20345 ] {8f5aba2d-c408-4853-928d-7b0813952bd8} TCPHandler: Code: 42. DB::Exception: Number of arguments for function exp2 doesn't match: passed 2, should be 1: In scope SELECT exp2(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:08:19.464136 [ 20345 ] {d4dcf5fa-55f2-4ee0-aaf2-512708c21bca} executeQuery: Code: 42. DB::Exception: Function exponentialTimeDecayedAvg takes exactly one parameter. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT exponentialTimeDecayedAvg(NULL, NULL);) 2025.09.09 15:08:19.472659 [ 20345 ] {d4dcf5fa-55f2-4ee0-aaf2-512708c21bca} TCPHandler: Code: 42. DB::Exception: Function exponentialTimeDecayedAvg takes exactly one parameter. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:08:19.567367 [ 20345 ] {9bbb081c-c33b-4334-830c-2a3fcb5b7ff8} executeQuery: Code: 42. DB::Exception: Function exponentialTimeDecayedCount takes exactly one parameter. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT exponentialTimeDecayedCount(NULL, NULL);) 2025.09.09 15:08:19.572612 [ 20345 ] {9bbb081c-c33b-4334-830c-2a3fcb5b7ff8} TCPHandler: Code: 42. DB::Exception: Function exponentialTimeDecayedCount takes exactly one parameter. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:08:19.620075 [ 2785 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:08:19.649811 [ 20345 ] {1ce87490-cd09-4cd8-b01a-477815f8890e} executeQuery: Code: 42. DB::Exception: Function exponentialTimeDecayedMax takes exactly one parameter. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT exponentialTimeDecayedMax(NULL, NULL);) 2025.09.09 15:08:19.658036 [ 20345 ] {1ce87490-cd09-4cd8-b01a-477815f8890e} TCPHandler: Code: 42. DB::Exception: Function exponentialTimeDecayedMax takes exactly one parameter. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:08:19.742364 [ 20345 ] {5237ac7a-4a0a-4c1f-8f0b-e85747ab4a3a} executeQuery: Code: 42. DB::Exception: Function exponentialTimeDecayedSum takes exactly one parameter. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT exponentialTimeDecayedSum(NULL, NULL);) 2025.09.09 15:08:19.744954 [ 20345 ] {5237ac7a-4a0a-4c1f-8f0b-e85747ab4a3a} TCPHandler: Code: 42. DB::Exception: Function exponentialTimeDecayedSum takes exactly one parameter. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:08:20.000999 [ 2754 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:08:20.028636 [ 2811 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:08:20.052023 [ 2734 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:08:20.623428 [ 2829 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:08:21.009172 [ 2922 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:08:21.030817 [ 2911 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:08:21.053990 [ 2884 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:08:21.159897 [ 20345 ] {159bc09e-ecab-4274-93ea-a972b1e15242} executeQuery: Code: 42. DB::Exception: Number of arguments for function extractTextFromHTML doesn't match: passed 2, should be 1: In scope SELECT extractTextFromHTML(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT extractTextFromHTML(NULL, NULL);) 2025.09.09 15:08:21.173921 [ 20345 ] {159bc09e-ecab-4274-93ea-a972b1e15242} TCPHandler: Code: 42. DB::Exception: Number of arguments for function extractTextFromHTML doesn't match: passed 2, should be 1: In scope SELECT extractTextFromHTML(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:08:21.373291 [ 20345 ] {b3260de3-04dd-496f-a321-612e3e5d4ecd} executeQuery: Code: 42. DB::Exception: Number of arguments for function extractURLParameterNames doesn't match: passed 2, should be 1: In scope SELECT extractURLParameterNames(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT extractURLParameterNames(NULL, NULL);) 2025.09.09 15:08:21.377301 [ 20345 ] {b3260de3-04dd-496f-a321-612e3e5d4ecd} TCPHandler: Code: 42. DB::Exception: Number of arguments for function extractURLParameterNames doesn't match: passed 2, should be 1: In scope SELECT extractURLParameterNames(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:08:21.447579 [ 20345 ] {1acfd67b-4638-4827-b207-6e51853c9a54} executeQuery: Code: 42. DB::Exception: Number of arguments for function extractURLParameters doesn't match: passed 2, should be 1: In scope SELECT extractURLParameters(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT extractURLParameters(NULL, NULL);) 2025.09.09 15:08:21.452907 [ 20345 ] {1acfd67b-4638-4827-b207-6e51853c9a54} TCPHandler: Code: 42. DB::Exception: Number of arguments for function extractURLParameters doesn't match: passed 2, should be 1: In scope SELECT extractURLParameters(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:08:21.509579 [ 20345 ] {d9bac264-246a-4427-8f93-6fb5f9fab8bb} executeQuery: Code: 42. DB::Exception: Number of arguments for function factorial doesn't match: passed 2, should be 1: In scope SELECT factorial(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT factorial(NULL, NULL);) 2025.09.09 15:08:21.516588 [ 20345 ] {d9bac264-246a-4427-8f93-6fb5f9fab8bb} TCPHandler: Code: 42. DB::Exception: Number of arguments for function factorial doesn't match: passed 2, should be 1: In scope SELECT factorial(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:08:21.626562 [ 2856 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:08:21.933370 [ 20345 ] {0290ca22-a150-4298-b603-b8528e7bd6c7} executeQuery: Code: 48. DB::Exception: file is only implemented for type String: In scope SELECT file(NULL, NULL). (NOT_IMPLEMENTED) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT file(NULL, NULL);) 2025.09.09 15:08:21.941257 [ 20345 ] {0290ca22-a150-4298-b603-b8528e7bd6c7} TCPHandler: Code: 48. DB::Exception: file is only implemented for type String: In scope SELECT file(NULL, NULL). (NOT_IMPLEMENTED) 2025.09.09 15:08:22.014518 [ 2915 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:08:22.107002 [ 2920 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:08:22.104822 [ 2803 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:08:22.531399 [ 20345 ] {890f3e9a-fad3-464c-aa97-04eab47900e8} executeQuery: Code: 42. DB::Exception: Number of arguments for function finalizeAggregation doesn't match: passed 2, should be 1: In scope SELECT finalizeAggregation(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT finalizeAggregation(NULL, NULL);) 2025.09.09 15:08:22.546003 [ 20345 ] {890f3e9a-fad3-464c-aa97-04eab47900e8} TCPHandler: Code: 42. DB::Exception: Number of arguments for function finalizeAggregation doesn't match: passed 2, should be 1: In scope SELECT finalizeAggregation(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:08:22.619866 [ 20345 ] {03c71bf1-26c9-442f-8e4e-36c6b7affcdb} executeQuery: Code: 42. DB::Exception: Number of arguments for function firstLine doesn't match: passed 2, should be 1: In scope SELECT firstLine(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT firstLine(NULL, NULL);) 2025.09.09 15:08:22.627262 [ 20345 ] {03c71bf1-26c9-442f-8e4e-36c6b7affcdb} TCPHandler: Code: 42. DB::Exception: Number of arguments for function firstLine doesn't match: passed 2, should be 1: In scope SELECT firstLine(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:08:22.628409 [ 2981 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:08:22.689250 [ 20345 ] {4707d2a2-cf58-4dce-8f78-19a662f56460} executeQuery: Code: 42. DB::Exception: Number of arguments for function firstSignificantSubdomain doesn't match: passed 2, should be 1: In scope SELECT firstSignificantSubdomain(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT firstSignificantSubdomain(NULL, NULL);) 2025.09.09 15:08:22.699597 [ 20345 ] {4707d2a2-cf58-4dce-8f78-19a662f56460} TCPHandler: Code: 42. DB::Exception: Number of arguments for function firstSignificantSubdomain doesn't match: passed 2, should be 1: In scope SELECT firstSignificantSubdomain(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:08:23.017179 [ 3036 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:08:23.073374 [ 20345 ] {9c3b2be5-9688-4e20-abea-126245ace699} executeQuery: Code: 42. DB::Exception: Number of arguments for function firstSignificantSubdomainRFC doesn't match: passed 2, should be 1: In scope SELECT firstSignificantSubdomainRFC(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT firstSignificantSubdomainRFC(NULL, NULL);) 2025.09.09 15:08:23.083471 [ 20345 ] {9c3b2be5-9688-4e20-abea-126245ace699} TCPHandler: Code: 42. DB::Exception: Number of arguments for function firstSignificantSubdomainRFC doesn't match: passed 2, should be 1: In scope SELECT firstSignificantSubdomainRFC(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:08:23.111002 [ 3060 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:08:23.145883 [ 3064 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:08:23.430167 [ 20345 ] {18c4bfb2-bf5e-41ee-9a54-77f8517f8162} executeQuery: Code: 42. DB::Exception: Aggregate function any_respect_nulls requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT first_value_respect_nulls(NULL, NULL);) 2025.09.09 15:08:23.435949 [ 20345 ] {18c4bfb2-bf5e-41ee-9a54-77f8517f8162} TCPHandler: Code: 42. DB::Exception: Aggregate function any_respect_nulls requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:08:23.484667 [ 20345 ] {eaf46480-9bbe-416f-9ff7-3861e221c0c4} executeQuery: Code: 43. DB::Exception: First argument (trace) for function flameGraph must be Array(UInt64), but it has type Nullable(Nothing). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT flameGraph(NULL, NULL);) 2025.09.09 15:08:23.488410 [ 20345 ] {eaf46480-9bbe-416f-9ff7-3861e221c0c4} TCPHandler: Code: 43. DB::Exception: First argument (trace) for function flameGraph must be Array(UInt64), but it has type Nullable(Nothing). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.09.09 15:08:23.557345 [ 20345 ] {3b897bf1-83bb-4e8c-bf39-8381b27aabfd} executeQuery: Code: 42. DB::Exception: Number of arguments for function arrayFlatten doesn't match: passed 2, should be 1: In scope SELECT flatten(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT flatten(NULL, NULL);) 2025.09.09 15:08:23.575369 [ 20345 ] {3b897bf1-83bb-4e8c-bf39-8381b27aabfd} TCPHandler: Code: 42. DB::Exception: Number of arguments for function arrayFlatten doesn't match: passed 2, should be 1: In scope SELECT flatten(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:08:23.631515 [ 3095 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:08:23.683873 [ 20345 ] {69cfee4c-bbe5-423c-9640-ec7d752bf354} executeQuery: Code: 42. DB::Exception: Number of arguments for function flattenTuple doesn't match: passed 2, should be 1: In scope SELECT flattenTuple(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT flattenTuple(NULL, NULL);) 2025.09.09 15:08:23.690215 [ 20345 ] {69cfee4c-bbe5-423c-9640-ec7d752bf354} TCPHandler: Code: 42. DB::Exception: Number of arguments for function flattenTuple doesn't match: passed 2, should be 1: In scope SELECT flattenTuple(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:08:24.019195 [ 3135 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:08:24.115783 [ 3133 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:08:24.149161 [ 3146 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:08:24.199349 [ 20345 ] {c58b7a6c-2441-4826-af45-fb282828da10} executeQuery: Code: 42. DB::Exception: Number of arguments for function formatQuery doesn't match: passed 2, should be 1: In scope SELECT formatQuery(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT formatQuery(NULL, NULL);) 2025.09.09 15:08:24.219127 [ 20345 ] {c58b7a6c-2441-4826-af45-fb282828da10} TCPHandler: Code: 42. DB::Exception: Number of arguments for function formatQuery doesn't match: passed 2, should be 1: In scope SELECT formatQuery(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:08:24.302614 [ 20345 ] {a6c01a66-8ca9-4867-b31c-00de0b73ea51} executeQuery: Code: 42. DB::Exception: Number of arguments for function formatQueryOrNull doesn't match: passed 2, should be 1: In scope SELECT formatQueryOrNull(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT formatQueryOrNull(NULL, NULL);) 2025.09.09 15:08:24.307297 [ 20345 ] {a6c01a66-8ca9-4867-b31c-00de0b73ea51} TCPHandler: Code: 42. DB::Exception: Number of arguments for function formatQueryOrNull doesn't match: passed 2, should be 1: In scope SELECT formatQueryOrNull(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:08:24.401511 [ 20345 ] {22a5a158-bb55-41e9-ace2-d89a1efba5ee} executeQuery: Code: 42. DB::Exception: Number of arguments for function formatQuerySingleLine doesn't match: passed 2, should be 1: In scope SELECT formatQuerySingleLine(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT formatQuerySingleLine(NULL, NULL);) 2025.09.09 15:08:24.409785 [ 20345 ] {22a5a158-bb55-41e9-ace2-d89a1efba5ee} TCPHandler: Code: 42. DB::Exception: Number of arguments for function formatQuerySingleLine doesn't match: passed 2, should be 1: In scope SELECT formatQuerySingleLine(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:08:24.507051 [ 20345 ] {f8f3782f-7a4d-4f8d-80d2-0f2fca3a9e90} executeQuery: Code: 42. DB::Exception: Number of arguments for function formatQuerySingleLineOrNull doesn't match: passed 2, should be 1: In scope SELECT formatQuerySingleLineOrNull(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT formatQuerySingleLineOrNull(NULL, NULL);) 2025.09.09 15:08:24.510514 [ 20345 ] {f8f3782f-7a4d-4f8d-80d2-0f2fca3a9e90} TCPHandler: Code: 42. DB::Exception: Number of arguments for function formatQuerySingleLineOrNull doesn't match: passed 2, should be 1: In scope SELECT formatQuerySingleLineOrNull(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:08:24.629004 [ 20345 ] {70742115-f671-427c-912a-a20a7b89f910} executeQuery: Code: 42. DB::Exception: Number of arguments for function formatReadableDecimalSize doesn't match: passed 2, should be 1: In scope SELECT formatReadableDecimalSize(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT formatReadableDecimalSize(NULL, NULL);) 2025.09.09 15:08:24.633337 [ 20345 ] {70742115-f671-427c-912a-a20a7b89f910} TCPHandler: Code: 42. DB::Exception: Number of arguments for function formatReadableDecimalSize doesn't match: passed 2, should be 1: In scope SELECT formatReadableDecimalSize(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:08:24.633631 [ 3193 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:08:24.798119 [ 20345 ] {3a1c92cc-e160-496d-90cf-cc2c9e06d5c9} executeQuery: Code: 42. DB::Exception: Number of arguments for function formatReadableQuantity doesn't match: passed 2, should be 1: In scope SELECT formatReadableQuantity(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT formatReadableQuantity(NULL, NULL);) 2025.09.09 15:08:24.803692 [ 20345 ] {3a1c92cc-e160-496d-90cf-cc2c9e06d5c9} TCPHandler: Code: 42. DB::Exception: Number of arguments for function formatReadableQuantity doesn't match: passed 2, should be 1: In scope SELECT formatReadableQuantity(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:08:24.867318 [ 20345 ] {ecc99c70-f159-4cef-ad18-70eca41c22d1} executeQuery: Code: 42. DB::Exception: Number of arguments for function formatReadableSize doesn't match: passed 2, should be 1: In scope SELECT formatReadableSize(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT formatReadableSize(NULL, NULL);) 2025.09.09 15:08:24.872692 [ 20345 ] {ecc99c70-f159-4cef-ad18-70eca41c22d1} TCPHandler: Code: 42. DB::Exception: Number of arguments for function formatReadableSize doesn't match: passed 2, should be 1: In scope SELECT formatReadableSize(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:08:25.020927 [ 2768 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:08:25.063872 [ 20345 ] {c6820631-7be1-4d53-98cd-21d943029da0} executeQuery: Code: 43. DB::Exception: First argument to formatRow must be a format name: In scope SELECT formatRow(NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT formatRow(NULL, NULL);) 2025.09.09 15:08:25.066097 [ 20345 ] {c6820631-7be1-4d53-98cd-21d943029da0} TCPHandler: Code: 43. DB::Exception: First argument to formatRow must be a format name: In scope SELECT formatRow(NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.09.09 15:08:25.122861 [ 2763 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:08:25.139248 [ 20345 ] {3f4235d7-3038-4021-bd36-57d74a4d7ee0} executeQuery: Code: 43. DB::Exception: First argument to formatRowNoNewline must be a format name: In scope SELECT formatRowNoNewline(NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT formatRowNoNewline(NULL, NULL);) 2025.09.09 15:08:25.151577 [ 2766 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:08:25.174964 [ 20345 ] {3f4235d7-3038-4021-bd36-57d74a4d7ee0} TCPHandler: Code: 43. DB::Exception: First argument to formatRowNoNewline must be a format name: In scope SELECT formatRowNoNewline(NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.09.09 15:08:25.303640 [ 20345 ] {e8be91b2-319f-45d3-88b6-e68e63cb0f6f} executeQuery: Code: 42. DB::Exception: Number of arguments for function fragment doesn't match: passed 2, should be 1: In scope SELECT fragment(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT fragment(NULL, NULL);) 2025.09.09 15:08:25.309554 [ 20345 ] {e8be91b2-319f-45d3-88b6-e68e63cb0f6f} TCPHandler: Code: 42. DB::Exception: Number of arguments for function fragment doesn't match: passed 2, should be 1: In scope SELECT fragment(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:08:25.439861 [ 20345 ] {5fa2f135-d55f-4bb7-b090-1c51c9b1def1} executeQuery: Code: 42. DB::Exception: Number of arguments for function fromDaysSinceYearZero doesn't match: passed 2, should be 1: In scope SELECT fromDaysSinceYearZero(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT fromDaysSinceYearZero(NULL, NULL);) 2025.09.09 15:08:25.448870 [ 20345 ] {5fa2f135-d55f-4bb7-b090-1c51c9b1def1} TCPHandler: Code: 42. DB::Exception: Number of arguments for function fromDaysSinceYearZero doesn't match: passed 2, should be 1: In scope SELECT fromDaysSinceYearZero(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:08:25.512964 [ 20345 ] {e2160346-b46e-48bc-b649-ba916ae4e62e} executeQuery: Code: 42. DB::Exception: Number of arguments for function fromDaysSinceYearZero32 doesn't match: passed 2, should be 1: In scope SELECT fromDaysSinceYearZero32(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT fromDaysSinceYearZero32(NULL, NULL);) 2025.09.09 15:08:25.517654 [ 20345 ] {e2160346-b46e-48bc-b649-ba916ae4e62e} TCPHandler: Code: 42. DB::Exception: Number of arguments for function fromDaysSinceYearZero32 doesn't match: passed 2, should be 1: In scope SELECT fromDaysSinceYearZero32(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:08:25.639804 [ 2787 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:08:25.678859 [ 20345 ] {533bb496-2e7f-4eeb-b964-4be572eeac2f} executeQuery: Code: 42. DB::Exception: Number of arguments for function fromModifiedJulianDay doesn't match: passed 2, should be 1: In scope SELECT fromModifiedJulianDay(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT fromModifiedJulianDay(NULL, NULL);) 2025.09.09 15:08:25.687211 [ 20345 ] {533bb496-2e7f-4eeb-b964-4be572eeac2f} TCPHandler: Code: 42. DB::Exception: Number of arguments for function fromModifiedJulianDay doesn't match: passed 2, should be 1: In scope SELECT fromModifiedJulianDay(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:08:25.703447 [ 20351 ] {aa04bc4c-6094-4334-8ab0-0bac74b6e1d2} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:40382) (comment: 02841_parallel_final_wrong_columns_order.sql) (in query: DROP DATABASE IF EXISTS test_iw5uufmy ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aac868e 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x00000000286b57c7 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x00000000291f5630 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:361: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000291edc97 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x00000000291ebf11 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x00000000291eb7ed 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b382fc 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1529: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000029b3ed3f 11. ./build_docker/./src/Server/HTTPHandler.cpp:529: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000002d0662d1 12. ./build_docker/./src/Server/HTTPHandler.cpp:705: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000002d06d139 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000002d1cc337 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 18. asan_thread_start(void*) @ 0x000000000aa43059 19. ? @ 0x00007f35aab92ac3 20. ? @ 0x00007f35aac24850 2025.09.09 15:08:25.711585 [ 20351 ] {aa04bc4c-6094-4334-8ab0-0bac74b6e1d2} DynamicQueryHandler: Code: 219. DB::Exception: New table 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aac868e 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x00000000286b57c7 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x00000000291f5630 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:361: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000291edc97 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x00000000291ebf11 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x00000000291eb7ed 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b382fc 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1529: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000029b3ed3f 11. ./build_docker/./src/Server/HTTPHandler.cpp:529: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000002d0662d1 12. ./build_docker/./src/Server/HTTPHandler.cpp:705: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000002d06d139 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000002d1cc337 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 18. asan_thread_start(void*) @ 0x000000000aa43059 19. ? @ 0x00007f35aab92ac3 20. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:08:25.852982 [ 20353 ] {0ed69606-4bd9-4a94-9792-ef646c1178c3} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:40384) (comment: 02841_parallel_final_wrong_columns_order.sql) (in query: DROP DATABASE IF EXISTS test_iw5uufmy ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aac868e 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x00000000286b57c7 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x00000000291f5630 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:361: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000291edc97 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x00000000291ebf11 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x00000000291eb7ed 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b382fc 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1529: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000029b3ed3f 11. ./build_docker/./src/Server/HTTPHandler.cpp:529: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000002d0662d1 12. ./build_docker/./src/Server/HTTPHandler.cpp:705: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000002d06d139 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000002d1cc337 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 18. asan_thread_start(void*) @ 0x000000000aa43059 19. ? @ 0x00007f35aab92ac3 20. ? @ 0x00007f35aac24850 2025.09.09 15:08:25.866367 [ 20353 ] {0ed69606-4bd9-4a94-9792-ef646c1178c3} DynamicQueryHandler: Code: 219. DB::Exception: New table 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aac868e 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x00000000286b57c7 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x00000000291f5630 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:361: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000291edc97 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x00000000291ebf11 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x00000000291eb7ed 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b382fc 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1529: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000029b3ed3f 11. ./build_docker/./src/Server/HTTPHandler.cpp:529: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000002d0662d1 12. ./build_docker/./src/Server/HTTPHandler.cpp:705: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000002d06d139 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000002d1cc337 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 18. asan_thread_start(void*) @ 0x000000000aa43059 19. ? @ 0x00007f35aab92ac3 20. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:08:25.949829 [ 20345 ] {a3b2b341-51f7-456b-9b66-998757bf0f94} executeQuery: Code: 42. DB::Exception: Number of arguments for function fromModifiedJulianDayOrNull doesn't match: passed 2, should be 1: In scope SELECT fromModifiedJulianDayOrNull(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT fromModifiedJulianDayOrNull(NULL, NULL);) 2025.09.09 15:08:25.958081 [ 20345 ] {a3b2b341-51f7-456b-9b66-998757bf0f94} TCPHandler: Code: 42. DB::Exception: Number of arguments for function fromModifiedJulianDayOrNull doesn't match: passed 2, should be 1: In scope SELECT fromModifiedJulianDayOrNull(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:08:26.023333 [ 2816 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:08:26.072286 [ 20351 ] {9bf1289e-41c5-4200-a111-78c7523961a8} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:40392) (comment: 02841_parallel_final_wrong_columns_order.sql) (in query: DROP DATABASE IF EXISTS test_iw5uufmy ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aac868e 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x00000000286b57c7 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x00000000291f5630 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:361: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000291edc97 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x00000000291ebf11 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x00000000291eb7ed 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b382fc 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1529: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000029b3ed3f 11. ./build_docker/./src/Server/HTTPHandler.cpp:529: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000002d0662d1 12. ./build_docker/./src/Server/HTTPHandler.cpp:705: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000002d06d139 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000002d1cc337 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 18. asan_thread_start(void*) @ 0x000000000aa43059 19. ? @ 0x00007f35aab92ac3 20. ? @ 0x00007f35aac24850 2025.09.09 15:08:26.078353 [ 20351 ] {9bf1289e-41c5-4200-a111-78c7523961a8} DynamicQueryHandler: Code: 219. DB::Exception: New table 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aac868e 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x00000000286b57c7 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x00000000291f5630 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:361: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000291edc97 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x00000000291ebf11 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x00000000291eb7ed 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b382fc 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1529: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000029b3ed3f 11. ./build_docker/./src/Server/HTTPHandler.cpp:529: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000002d0662d1 12. ./build_docker/./src/Server/HTTPHandler.cpp:705: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000002d06d139 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000002d1cc337 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 18. asan_thread_start(void*) @ 0x000000000aa43059 19. ? @ 0x00007f35aab92ac3 20. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:08:26.131401 [ 2825 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:08:26.154665 [ 2810 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:08:26.232660 [ 20353 ] {b95c2c10-1ae9-4d52-bb2f-8ab9310c1fe5} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:40406) (comment: 02841_parallel_final_wrong_columns_order.sql) (in query: DROP DATABASE IF EXISTS test_iw5uufmy ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aac868e 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x00000000286b57c7 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x00000000291f5630 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:361: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000291edc97 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x00000000291ebf11 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x00000000291eb7ed 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b382fc 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1529: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000029b3ed3f 11. ./build_docker/./src/Server/HTTPHandler.cpp:529: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000002d0662d1 12. ./build_docker/./src/Server/HTTPHandler.cpp:705: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000002d06d139 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000002d1cc337 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 18. asan_thread_start(void*) @ 0x000000000aa43059 19. ? @ 0x00007f35aab92ac3 20. ? @ 0x00007f35aac24850 2025.09.09 15:08:26.238660 [ 20353 ] {b95c2c10-1ae9-4d52-bb2f-8ab9310c1fe5} DynamicQueryHandler: Code: 219. DB::Exception: New table 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aac868e 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x00000000286b57c7 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x00000000291f5630 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:361: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000291edc97 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x00000000291ebf11 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x00000000291eb7ed 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b382fc 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1529: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000029b3ed3f 11. ./build_docker/./src/Server/HTTPHandler.cpp:529: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000002d0662d1 12. ./build_docker/./src/Server/HTTPHandler.cpp:705: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000002d06d139 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000002d1cc337 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 18. asan_thread_start(void*) @ 0x000000000aa43059 19. ? @ 0x00007f35aab92ac3 20. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:08:26.642836 [ 2812 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:08:27.025750 [ 2851 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:08:27.137852 [ 2907 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:08:27.159588 [ 2908 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:08:27.323198 [ 20345 ] {6b4edefe-e712-4f3b-9dee-4dee356de8f8} executeQuery: Code: 42. DB::Exception: Number of arguments for function FQDN doesn't match: passed 2, should be 0: In scope SELECT fullHostName(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT fullHostName(NULL, NULL);) 2025.09.09 15:08:27.328202 [ 20345 ] {6b4edefe-e712-4f3b-9dee-4dee356de8f8} TCPHandler: Code: 42. DB::Exception: Number of arguments for function FQDN doesn't match: passed 2, should be 0: In scope SELECT fullHostName(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:08:27.455717 [ 20380 ] {3f747356-7799-429c-a7d0-7c5ff7fe12dd} executeQuery: Code: 241. DB::Exception: Memory tracker (for query): fault injected. Would use 30.83 MiB (attempt to allocate chunk of 1179651 bytes), maximum: 9.31 GiB: (avg_value_size_hint = 14.88909912109375, avg_chars_size = 8.266918945312499, limit = 16384): (while reading column l): (while reading from part /var/lib/clickhouse/store/a35/a35263b5-8f54-4fe9-87ac-396610745dea/all_1_1_0/ in table test_1.tab2 (a35263b5-8f54-4fe9-87ac-396610745dea) located on disk default of type local, from mark 61 with max_rows_to_read = 16384): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder). (MEMORY_LIMIT_EXCEEDED) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:44852) (comment: 02841_parallel_final_wrong_columns_order.sql) (in query: select count() from tab2 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, char const*&&, String&&, long&, String&&) @ 0x000000001adfc3f5 4. ./build_docker/./src/Common/MemoryTracker.cpp:284: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001adfafab 5. ./build_docker/./src/Common/MemoryTracker.cpp:0: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001adfa777 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:59: CurrentMemoryTracker::alloc(long) @ 0x000000001ad3289d 7. ./build_docker/./src/Common/Allocator.cpp:151: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001ad2eb85 8. ./src/Common/PODArray.h:120: DB::SerializationString::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x0000000027c0e979 9. ./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 @ 0x0000000027aa00db 10. ./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) @ 0x000000002c80211e 11. ./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>>&) @ 0x000000002c800e8d 12. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:118: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7c9d8a 13. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x000000002c7e0473 14. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x000000002c7dbec3 15. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:0: DB::MergeTreeReadTask::read(DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002c82d05b 16. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:53: DB::MergeTreeInOrderSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&, DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002dea5374 17. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:0: DB::MergeTreeSelectProcessor::read() @ 0x000000002c8242f9 18. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000002de6d77a 19. ./build_docker/./src/Processors/ISource.cpp:0: DB::ISource::work() @ 0x000000002d3290a1 20. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:381: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000002d34bd35 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7eaf0 24. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001af8a79f 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 27. asan_thread_start(void*) @ 0x000000000aa43059 28. ? @ 0x00007f35aab92ac3 29. ? @ 0x00007f35aac24850 2025.09.09 15:08:27.483156 [ 20380 ] {3f747356-7799-429c-a7d0-7c5ff7fe12dd} TCPHandler: Code: 241. DB::Exception: Memory tracker (for query): fault injected. Would use 30.83 MiB (attempt to allocate chunk of 1179651 bytes), maximum: 9.31 GiB: (avg_value_size_hint = 14.88909912109375, avg_chars_size = 8.266918945312499, limit = 16384): (while reading column l): (while reading from part /var/lib/clickhouse/store/a35/a35263b5-8f54-4fe9-87ac-396610745dea/all_1_1_0/ in table test_1.tab2 (a35263b5-8f54-4fe9-87ac-396610745dea) located on disk default of type local, from mark 61 with max_rows_to_read = 16384): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder). (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, char const*&&, String&&, long&, String&&) @ 0x000000001adfc3f5 4. ./build_docker/./src/Common/MemoryTracker.cpp:284: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001adfafab 5. ./build_docker/./src/Common/MemoryTracker.cpp:0: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001adfa777 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:59: CurrentMemoryTracker::alloc(long) @ 0x000000001ad3289d 7. ./build_docker/./src/Common/Allocator.cpp:151: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001ad2eb85 8. ./src/Common/PODArray.h:120: DB::SerializationString::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x0000000027c0e979 9. ./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 @ 0x0000000027aa00db 10. ./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) @ 0x000000002c80211e 11. ./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>>&) @ 0x000000002c800e8d 12. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:118: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7c9d8a 13. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x000000002c7e0473 14. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x000000002c7dbec3 15. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:0: DB::MergeTreeReadTask::read(DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002c82d05b 16. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:53: DB::MergeTreeInOrderSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&, DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002dea5374 17. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:0: DB::MergeTreeSelectProcessor::read() @ 0x000000002c8242f9 18. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000002de6d77a 19. ./build_docker/./src/Processors/ISource.cpp:0: DB::ISource::work() @ 0x000000002d3290a1 20. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:381: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000002d34bd35 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7eaf0 24. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001af8a79f 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 27. asan_thread_start(void*) @ 0x000000000aa43059 28. ? @ 0x00007f35aab92ac3 29. ? @ 0x00007f35aac24850 2025.09.09 15:08:27.645578 [ 2947 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:08:27.930571 [ 20345 ] {47e1fd4d-9439-482b-9714-9a1a84f09e69} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 2nd argument 'machine_id' to function 'generateSnowflakeID'. Expected: const UInt*, got: Nullable(Nothing): In scope SELECT generateSnowflakeID(NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT generateSnowflakeID(NULL, NULL);) 2025.09.09 15:08:27.935715 [ 20345 ] {47e1fd4d-9439-482b-9714-9a1a84f09e69} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 2nd argument 'machine_id' to function 'generateSnowflakeID'. Expected: const UInt*, got: Nullable(Nothing): In scope SELECT generateSnowflakeID(NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.09.09 15:08:28.028095 [ 2997 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:08:28.193726 [ 3015 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:08:28.203043 [ 3005 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:08:28.211229 [ 20345 ] {465a9b0c-c331-4dbf-84e6-fbec8b8d7f7a} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'generateUUIDv4'. Expected 1 optional argument, got 2 arguments: In scope SELECT generateUUIDv4(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT generateUUIDv4(NULL, NULL);) 2025.09.09 15:08:28.219410 [ 20345 ] {465a9b0c-c331-4dbf-84e6-fbec8b8d7f7a} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'generateUUIDv4'. Expected 1 optional argument, got 2 arguments: In scope SELECT generateUUIDv4(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:08:28.284500 [ 20345 ] {203f4aa1-cef5-44b1-91ae-17588777d210} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'generateUUIDv7'. Expected 1 optional argument, got 2 arguments: In scope SELECT generateUUIDv7(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT generateUUIDv7(NULL, NULL);) 2025.09.09 15:08:28.290336 [ 20345 ] {203f4aa1-cef5-44b1-91ae-17588777d210} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'generateUUIDv7'. Expected 1 optional argument, got 2 arguments: In scope SELECT generateUUIDv7(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:08:28.391686 [ 20345 ] {d616fbc3-7e04-4821-a83a-2df3d46dd4ef} executeQuery: Code: 42. DB::Exception: Number of arguments for function geoDistance doesn't match: passed 2, should be 4: In scope SELECT geoDistance(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT geoDistance(NULL, NULL);) 2025.09.09 15:08:28.395725 [ 20345 ] {d616fbc3-7e04-4821-a83a-2df3d46dd4ef} TCPHandler: Code: 42. DB::Exception: Number of arguments for function geoDistance doesn't match: passed 2, should be 4: In scope SELECT geoDistance(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:08:28.477846 [ 20345 ] {e7fe4962-b689-4cf5-b004-35e59d2b13d5} executeQuery: Code: 42. DB::Exception: Number of arguments for function geoToH3 doesn't match: passed 2, should be 3: In scope SELECT geoToH3(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT geoToH3(NULL, NULL);) 2025.09.09 15:08:28.486082 [ 20345 ] {e7fe4962-b689-4cf5-b004-35e59d2b13d5} TCPHandler: Code: 42. DB::Exception: Number of arguments for function geoToH3 doesn't match: passed 2, should be 3: In scope SELECT geoToH3(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:08:28.648300 [ 3078 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:08:28.722356 [ 20379 ] {47e6962b-8526-4f57-b280-50df73bf5319} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=790, jobs=740). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:56366) (in query: select value, changed from system.settings where name='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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af872f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af7b2d1 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af7c3f3 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d36920d 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000002d369e5f 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processOrdinaryQuery() @ 0x000000002d18af7b 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d17644a 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 15. asan_thread_start(void*) @ 0x000000000aa43059 16. ? @ 0x00007f35aab92ac3 17. ? @ 0x00007f35aac24850 2025.09.09 15:08:28.739500 [ 20379 ] {47e6962b-8526-4f57-b280-50df73bf5319} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=790, jobs=740). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af872f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af7b2d1 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af7c3f3 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d36920d 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000002d369e5f 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processOrdinaryQuery() @ 0x000000002d18af7b 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d17644a 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 15. asan_thread_start(void*) @ 0x000000000aa43059 16. ? @ 0x00007f35aab92ac3 17. ? @ 0x00007f35aac24850 2025.09.09 15:08:28.863630 [ 20345 ] {c7fb4cd0-425b-4dd4-9add-a31c2589d16e} executeQuery: Code: 42. DB::Exception: Number of arguments for function geohashDecode doesn't match: passed 2, should be 1: In scope SELECT geohashDecode(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT geohashDecode(NULL, NULL);) 2025.09.09 15:08:28.882348 [ 20345 ] {c7fb4cd0-425b-4dd4-9add-a31c2589d16e} TCPHandler: Code: 42. DB::Exception: Number of arguments for function geohashDecode doesn't match: passed 2, should be 1: In scope SELECT geohashDecode(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:08:29.033090 [ 3076 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:08:29.198498 [ 3100 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:08:29.201874 [ 20345 ] {c9a373d1-7abc-42db-b0df-d18ad5b5d4b2} executeQuery: Code: 42. DB::Exception: Number of arguments for function geohashesInBox doesn't match: passed 2, should be 5: In scope SELECT geohashesInBox(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT geohashesInBox(NULL, NULL);) 2025.09.09 15:08:29.205236 [ 20345 ] {c9a373d1-7abc-42db-b0df-d18ad5b5d4b2} TCPHandler: Code: 42. DB::Exception: Number of arguments for function geohashesInBox doesn't match: passed 2, should be 5: In scope SELECT geohashesInBox(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:08:29.205584 [ 3085 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:08:29.248902 [ 3331 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {166e6d4b-ecec-41a4-ad4a-0c1c77ff9a47::202509_290_300_2}: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=13, jobs=0). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af80b71 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80746 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002c765aab 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:1197: ? @ 0x000000002c7602b8 8. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x000000002c75fc2b 9. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:0: DB::MergeTreeReaderCompact::MergeTreeReaderCompact(std::shared_ptr, DB::NamesAndTypesList, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*, DB::MarkCache*, DB::MarkRanges, DB::MergeTreeReaderSettings, std::map, std::allocator>>, std::function const&, int) @ 0x000000002c7aee03 10. ./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.h:16: DB::MergeTreeReaderCompactSingleBuffer::MergeTreeReaderCompactSingleBuffer&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int&&) @ 0x000000002c5d6d21 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::MergeTreeDataPartCompact::getReader(DB::NamesAndTypesList const&, std::shared_ptr const&, DB::MarkRanges const&, std::unordered_map, std::equal_to, std::allocator>> const&, DB::UncompressedCache*, DB::MarkCache*, std::shared_ptr const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) const @ 0x000000002c5d1037 12. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:169: DB::MergeTreeSequentialSource::MergeTreeSequentialSource(DB::MergeTreeSequentialSourceType, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::vector>, std::optional, bool, bool, bool) @ 0x000000002c80c330 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:35: DB::MergeTreeSequentialSource* std::construct_at[abi:v15007] const&, std::shared_ptr&, std::shared_ptr&, std::vector>&, std::optional, bool, bool&, bool&, DB::MergeTreeSequentialSource*>(DB::MergeTreeSequentialSource*, DB::MergeTreeSequentialSourceType&, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr&, std::shared_ptr&, std::vector>&, std::optional&&, bool&&, bool&, bool&) @ 0x000000002c81320f 14. ./contrib/llvm-project/libcxx/include/__memory/allocator_traits.h:298: DB::createMergeTreeSequentialSource(DB::MergeTreeSequentialSourceType, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::vector>, std::optional, std::shared_ptr>, bool, bool, bool) @ 0x000000002c810812 15. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1136: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::createMergedStream() @ 0x000000002c3dd079 16. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() @ 0x000000002c3d6516 17. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:534: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x000000002c3e2799 18. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::execute() @ 0x000000002c3ef3fe 19. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:0: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000002cc2f4c0 20. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000002c427f28 21. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000002c429675 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7eaf0 23. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001af8a79f 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 26. asan_thread_start(void*) @ 0x000000000aa43059 27. ? @ 0x00007f35aab92ac3 28. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:08:29.316873 [ 20345 ] {f357eb1a-ef6c-400a-96d5-231c68e0a799} executeQuery: Code: 446. DB::Exception: The function getClientHTTPHeader requires setting `allow_get_client_http_header` to be enabled. (FUNCTION_NOT_ALLOWED) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT getClientHTTPHeader(NULL, NULL);) 2025.09.09 15:08:29.333346 [ 20345 ] {f357eb1a-ef6c-400a-96d5-231c68e0a799} TCPHandler: Code: 446. DB::Exception: The function getClientHTTPHeader requires setting `allow_get_client_http_header` to be enabled. (FUNCTION_NOT_ALLOWED) 2025.09.09 15:08:29.427415 [ 20345 ] {95ea497d-3ee6-4d4b-88d0-93a333470659} executeQuery: Code: 42. DB::Exception: Number of arguments for function getMacro doesn't match: passed 2, should be 1: In scope SELECT getMacro(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT getMacro(NULL, NULL);) 2025.09.09 15:08:29.432818 [ 20345 ] {95ea497d-3ee6-4d4b-88d0-93a333470659} TCPHandler: Code: 42. DB::Exception: Number of arguments for function getMacro doesn't match: passed 2, should be 1: In scope SELECT getMacro(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:08:29.501091 [ 20345 ] {37c17aed-8568-4f57-9eaa-acb1d09c2b71} executeQuery: Code: 42. DB::Exception: Number of arguments for function getOSKernelVersion doesn't match: passed 2, should be 0: In scope SELECT getOSKernelVersion(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT getOSKernelVersion(NULL, NULL);) 2025.09.09 15:08:29.507382 [ 20345 ] {37c17aed-8568-4f57-9eaa-acb1d09c2b71} TCPHandler: Code: 42. DB::Exception: Number of arguments for function getOSKernelVersion doesn't match: passed 2, should be 0: In scope SELECT getOSKernelVersion(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:08:29.607571 [ 20345 ] {d003df58-04b3-410b-89e8-4948f733d325} executeQuery: Code: 42. DB::Exception: Number of arguments for function getServerPort doesn't match: passed 2, should be 1: In scope SELECT getServerPort(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT getServerPort(NULL, NULL);) 2025.09.09 15:08:29.636427 [ 20345 ] {d003df58-04b3-410b-89e8-4948f733d325} TCPHandler: Code: 42. DB::Exception: Number of arguments for function getServerPort doesn't match: passed 2, should be 1: In scope SELECT getServerPort(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:08:29.650170 [ 3123 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:08:29.721261 [ 20345 ] {766a9776-d2de-4cf3-9d7e-9e718a8af06f} executeQuery: Code: 42. DB::Exception: Number of arguments for function getSetting doesn't match: passed 2, should be 1: In scope SELECT getSetting(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT getSetting(NULL, NULL);) 2025.09.09 15:08:29.731519 [ 20379 ] {} TCPHandler: Code: 164. DB::Exception: Cannot modify 'send_logs_level' 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage const&, int) @ 0x0000000025fae8e5 3. ./build_docker/./src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f81304 4. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 5. ./contrib/llvm-project/libcxx/include/__algorithm/find_if.h:25: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f808a4 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 7. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 8. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 11. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 15. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 16. asan_thread_start(void*) @ 0x000000000aa43059 17. ? @ 0x00007f35aab92ac3 18. ? @ 0x00007f35aac24850 2025.09.09 15:08:29.742820 [ 20345 ] {766a9776-d2de-4cf3-9d7e-9e718a8af06f} TCPHandler: Code: 42. DB::Exception: Number of arguments for function getSetting doesn't match: passed 2, should be 1: In scope SELECT getSetting(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:08:29.837674 [ 20345 ] {e2ade615-e19e-4c27-aba8-9c2d4e63d9b5} executeQuery: Code: 42. DB::Exception: Number of arguments for function getSizeOfEnumType doesn't match: passed 2, should be 1: In scope SELECT getSizeOfEnumType(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT getSizeOfEnumType(NULL, NULL);) 2025.09.09 15:08:29.842500 [ 20345 ] {e2ade615-e19e-4c27-aba8-9c2d4e63d9b5} TCPHandler: Code: 42. DB::Exception: Number of arguments for function getSizeOfEnumType doesn't match: passed 2, should be 1: In scope SELECT getSizeOfEnumType(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:08:30.000539 [ 20380 ] {ef181ac3-67d8-44dc-a9f1-8ad4fb436b25} executeQuery: Code: 48. DB::Exception: Cannot rename and modify the same column `value1_string` in a single ALTER query. (NOT_IMPLEMENTED) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:56392) (comment: 01281_alter_rename_and_other_renames.sql) (in query: ALTER TABLE rename_table_multiple RENAME COLUMN value1 TO value1_string, MODIFY COLUMN value1_string 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000aad4b34 4. ./build_docker/./src/Storages/AlterCommands.cpp:1373: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x000000002b607b15 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:207: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000291744d2 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x0000000029170711 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b382fc 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 15. asan_thread_start(void*) @ 0x000000000aa43059 16. ? @ 0x00007f35aab92ac3 17. ? @ 0x00007f35aac24850 2025.09.09 15:08:30.004736 [ 20380 ] {ef181ac3-67d8-44dc-a9f1-8ad4fb436b25} TCPHandler: Code: 48. DB::Exception: Cannot rename and modify the same column `value1_string` in a single ALTER query. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000aad4b34 4. ./build_docker/./src/Storages/AlterCommands.cpp:1373: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x000000002b607b15 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:207: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000291744d2 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x0000000029170711 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b382fc 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 15. asan_thread_start(void*) @ 0x000000000aa43059 16. ? @ 0x00007f35aab92ac3 17. ? @ 0x00007f35aac24850 2025.09.09 15:08:30.054883 [ 3181 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:08:30.169623 [ 20345 ] {7e11e51e-e8e6-4023-9a08-b9622ac43e3e} executeQuery: Code: 42. DB::Exception: Number of arguments for function getTypeSerializationStreams doesn't match: passed 2, should be 1: In scope SELECT getTypeSerializationStreams(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT getTypeSerializationStreams(NULL, NULL);) 2025.09.09 15:08:30.194152 [ 20345 ] {7e11e51e-e8e6-4023-9a08-b9622ac43e3e} TCPHandler: Code: 42. DB::Exception: Number of arguments for function getTypeSerializationStreams doesn't match: passed 2, should be 1: In scope SELECT getTypeSerializationStreams(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:08:30.200959 [ 3167 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:08:30.208222 [ 3171 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:08:30.208257 [ 20379 ] {} TCPHandler: Code: 164. DB::Exception: Cannot modify 'ignore_drop_queries_probability' 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage const&, int) @ 0x0000000025fae8e5 3. ./build_docker/./src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f81304 4. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 5. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f80932 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853ad81 7. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853b971 8. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1a17ad 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1877e2 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d175061 11. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 15. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 16. asan_thread_start(void*) @ 0x000000000aa43059 17. ? @ 0x00007f35aab92ac3 18. ? @ 0x00007f35aac24850 2025.09.09 15:08:30.264105 [ 20380 ] {16afa38d-ca3d-42cc-ba4c-b7b96684f7fd} executeQuery: Code: 48. DB::Exception: Cannot rename and modify the same column `value1` in a single ALTER query. (NOT_IMPLEMENTED) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:56392) (comment: 01281_alter_rename_and_other_renames.sql) (in query: ALTER TABLE rename_table_multiple MODIFY COLUMN value1 String, RENAME COLUMN value1 to value1_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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000aad4b34 4. ./build_docker/./src/Storages/AlterCommands.cpp:1572: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x000000002b607954 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:207: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000291744d2 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x0000000029170711 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b382fc 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 15. asan_thread_start(void*) @ 0x000000000aa43059 16. ? @ 0x00007f35aab92ac3 17. ? @ 0x00007f35aac24850 2025.09.09 15:08:30.267395 [ 20380 ] {16afa38d-ca3d-42cc-ba4c-b7b96684f7fd} TCPHandler: Code: 48. DB::Exception: Cannot rename and modify the same column `value1` in a single ALTER query. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000aad4b34 4. ./build_docker/./src/Storages/AlterCommands.cpp:1572: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x000000002b607954 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:207: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000291744d2 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x0000000029170711 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b382fc 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 15. asan_thread_start(void*) @ 0x000000000aa43059 16. ? @ 0x00007f35aab92ac3 17. ? @ 0x00007f35aac24850 2025.09.09 15:08:30.300961 [ 20351 ] {af9fcc5b-effa-45ef-8a76-f8af32017e4c} executeQuery: Code: 48. DB::Exception: WITH TOTALS and WITH ROLLUP or CUBE are not supported together in presence of QUALIFY. (NOT_IMPLEMENTED) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:56358) (comment: 03095_window_functions_qualify.sql) (in query: SELECT number % toUInt256(2) AS key, count() FROM numbers(10) GROUP BY key WITH CUBE WITH TOTALS QUALIFY key = toNullable(toNullable(0));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aac868e 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5296: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002835dac5 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000028359104 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000028357f0d 7. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002921bdcc 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&) @ 0x000000002941f313 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&) @ 0x0000000029419aef 10. ./contrib/llvm-project/libcxx/include/vector:432: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000029421f5d 11. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000029344c1b 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*) @ 0x0000000029b3703b 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 15. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 19. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 20. asan_thread_start(void*) @ 0x000000000aa43059 21. ? @ 0x00007f35aab92ac3 22. ? @ 0x00007f35aac24850 2025.09.09 15:08:30.304025 [ 20351 ] {af9fcc5b-effa-45ef-8a76-f8af32017e4c} TCPHandler: Code: 48. DB::Exception: WITH TOTALS and WITH ROLLUP or CUBE are not supported together in presence of QUALIFY. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aac868e 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5296: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002835dac5 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000028359104 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000028357f0d 7. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002921bdcc 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&) @ 0x000000002941f313 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&) @ 0x0000000029419aef 10. ./contrib/llvm-project/libcxx/include/vector:432: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000029421f5d 11. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000029344c1b 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*) @ 0x0000000029b3703b 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 15. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 19. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 20. asan_thread_start(void*) @ 0x000000000aa43059 21. ? @ 0x00007f35aab92ac3 22. ? @ 0x00007f35aac24850 2025.09.09 15:08:30.381987 [ 20351 ] {ab582ce7-748c-4f6a-a1e9-9b9473ee2c07} executeQuery: Code: 48. DB::Exception: WITH TOTALS and WITH ROLLUP or CUBE are not supported together in presence of QUALIFY. (NOT_IMPLEMENTED) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:56358) (comment: 03095_window_functions_qualify.sql) (in query: SELECT number % 2 AS key, count(materialize(5)) IGNORE NULLS FROM numbers(10) WHERE toLowCardinality(toLowCardinality(materialize(2))) GROUP BY key WITH CUBE WITH TOTALS QUALIFY key = 0;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aac868e 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5296: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002835dac5 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000028359104 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000028357f0d 7. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002921bdcc 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&) @ 0x000000002941f313 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&) @ 0x0000000029419aef 10. ./contrib/llvm-project/libcxx/include/vector:432: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000029421f5d 11. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000029344c1b 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*) @ 0x0000000029b3703b 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 15. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 19. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 20. asan_thread_start(void*) @ 0x000000000aa43059 21. ? @ 0x00007f35aab92ac3 22. ? @ 0x00007f35aac24850 2025.09.09 15:08:30.384431 [ 20351 ] {ab582ce7-748c-4f6a-a1e9-9b9473ee2c07} TCPHandler: Code: 48. DB::Exception: WITH TOTALS and WITH ROLLUP or CUBE are not supported together in presence of QUALIFY. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aac868e 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5296: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002835dac5 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000028359104 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000028357f0d 7. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002921bdcc 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&) @ 0x000000002941f313 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&) @ 0x0000000029419aef 10. ./contrib/llvm-project/libcxx/include/vector:432: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000029421f5d 11. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000029344c1b 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*) @ 0x0000000029b3703b 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 15. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 19. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 20. asan_thread_start(void*) @ 0x000000000aa43059 21. ? @ 0x00007f35aab92ac3 22. ? @ 0x00007f35aac24850 2025.09.09 15:08:30.418103 [ 20351 ] {8a9039d8-c913-4f38-a4da-d8cd355130fd} executeQuery: Code: 48. DB::Exception: WITH TOTALS and WITH ROLLUP or CUBE are not supported together in presence of QUALIFY. (NOT_IMPLEMENTED) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:56358) (comment: 03095_window_functions_qualify.sql) (in query: SELECT 4, count(4) IGNORE NULLS, number % 2 AS key FROM numbers(10) GROUP BY key WITH ROLLUP WITH TOTALS QUALIFY key = materialize(0);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aac868e 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5296: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002835dac5 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000028359104 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000028357f0d 7. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002921bdcc 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&) @ 0x000000002941f313 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&) @ 0x0000000029419aef 10. ./contrib/llvm-project/libcxx/include/vector:432: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000029421f5d 11. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000029344c1b 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*) @ 0x0000000029b3703b 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 15. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 19. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 20. asan_thread_start(void*) @ 0x000000000aa43059 21. ? @ 0x00007f35aab92ac3 22. ? @ 0x00007f35aac24850 2025.09.09 15:08:30.421584 [ 20351 ] {8a9039d8-c913-4f38-a4da-d8cd355130fd} TCPHandler: Code: 48. DB::Exception: WITH TOTALS and WITH ROLLUP or CUBE are not supported together in presence of QUALIFY. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aac868e 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5296: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002835dac5 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000028359104 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000028357f0d 7. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002921bdcc 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&) @ 0x000000002941f313 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&) @ 0x0000000029419aef 10. ./contrib/llvm-project/libcxx/include/vector:432: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000029421f5d 11. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000029344c1b 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*) @ 0x0000000029b3703b 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 15. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 19. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 20. asan_thread_start(void*) @ 0x000000000aa43059 21. ? @ 0x00007f35aab92ac3 22. ? @ 0x00007f35aac24850 2025.09.09 15:08:30.454786 [ 20351 ] {0f4ea7ef-0f53-4ae3-855a-91fbc36f822c} executeQuery: Code: 48. DB::Exception: WITH TOTALS and WITH ROLLUP or CUBE are not supported together in presence of QUALIFY. (NOT_IMPLEMENTED) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:56358) (comment: 03095_window_functions_qualify.sql) (in query: SELECT 3, number % toLowCardinality(2) AS key, count() IGNORE NULLS FROM numbers(10) GROUP BY key WITH ROLLUP WITH TOTALS QUALIFY key = 0;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aac868e 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5296: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002835dac5 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000028359104 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000028357f0d 7. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002921bdcc 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&) @ 0x000000002941f313 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&) @ 0x0000000029419aef 10. ./contrib/llvm-project/libcxx/include/vector:432: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000029421f5d 11. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000029344c1b 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*) @ 0x0000000029b3703b 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 15. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 19. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 20. asan_thread_start(void*) @ 0x000000000aa43059 21. ? @ 0x00007f35aab92ac3 22. ? @ 0x00007f35aac24850 2025.09.09 15:08:30.457260 [ 20351 ] {0f4ea7ef-0f53-4ae3-855a-91fbc36f822c} TCPHandler: Code: 48. DB::Exception: WITH TOTALS and WITH ROLLUP or CUBE are not supported together in presence of QUALIFY. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aac868e 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5296: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002835dac5 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000028359104 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000028357f0d 7. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002921bdcc 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&) @ 0x000000002941f313 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&) @ 0x0000000029419aef 10. ./contrib/llvm-project/libcxx/include/vector:432: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000029421f5d 11. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000029344c1b 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*) @ 0x0000000029b3703b 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 15. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 19. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 20. asan_thread_start(void*) @ 0x000000000aa43059 21. ? @ 0x00007f35aab92ac3 22. ? @ 0x00007f35aac24850 2025.09.09 15:08:30.652489 [ 3213 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:08:30.871453 [ 20379 ] {} DynamicQueryHandler: Code: 164. DB::Exception: Cannot modify 'readonly' setting in readonly mode: , while trying to set settings profile readonly: in attempt to set the value of setting 'profile' to 'readonly'. (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. ./contrib/llvm-project/libcxx/include/string:1499: DB::Exception::Exception(PreformattedMessage const&, int) @ 0x0000000025fae8e5 3. ./build_docker/./src/Access/SettingsConstraints.cpp:0: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f81304 4. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 5. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x0000000026f807e3 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges const&, DB::SettingSource) @ 0x0000000028529bc1 7. ./contrib/llvm-project/libcxx/include/vector:1463: DB::Context::setCurrentProfilesWithLock(DB::SettingsProfilesInfo const&, bool, std::lock_guard const&) @ 0x0000000028524279 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::setCurrentProfileWithLock(String const&, bool, std::lock_guard const&) @ 0x000000002852975e 9. ./build_docker/./src/Interpreters/Context.cpp:2341: DB::Context::applySettingChangeWithLock(DB::SettingChange const&, std::lock_guard const&) @ 0x000000002853924b 10. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::Context::applySettingsChanges(DB::SettingsChanges const&) @ 0x000000002853a34e 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000002d065744 12. ./build_docker/./src/Server/HTTPHandler.cpp:705: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000002d06d139 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000002d1cc337 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 18. asan_thread_start(void*) @ 0x000000000aa43059 19. ? @ 0x00007f35aab92ac3 20. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:08:31.057088 [ 2766 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:08:31.112107 [ 20345 ] {137d695c-4d1d-4533-bae1-75fa14e042af} executeQuery: Code: 42. DB::Exception: Number of arguments for function globalVariable doesn't match: passed 2, should be 1: In scope SELECT globalVariable(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT globalVariable(NULL, NULL);) 2025.09.09 15:08:31.116337 [ 20345 ] {137d695c-4d1d-4533-bae1-75fa14e042af} TCPHandler: Code: 42. DB::Exception: Number of arguments for function globalVariable doesn't match: passed 2, should be 1: In scope SELECT globalVariable(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:08:31.203129 [ 2733 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:08:31.210572 [ 2785 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:08:31.230523 [ 20380 ] {30629b8f-f1b9-4520-a8e6-da7ef99137d5} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=1, jobs=1). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:56392) (comment: 01281_alter_rename_and_other_renames.sql) (in query: SELECT * FROM rename_table_multiple ORDER BY key 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af80b71 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af82f33 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002c64fc80 7. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1723: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr, unsigned long, std::shared_ptr, std::equal_to, std::allocator>>>, DB::MergeTreeData const&, std::vector> const&, std::shared_ptr, std::optional&, bool) @ 0x000000002de379fd 8. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1437: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000002de3554f 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:0: DB::ReadFromMergeTree::getAnalysisResult() const @ 0x000000002de41345 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:2022: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000002de4404c 11. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000002ddb933c 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000002ddff11e 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000002942117f 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x00000000294209e7 15. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b382fc 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 18. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 22. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:08:31.232382 [ 20380 ] {30629b8f-f1b9-4520-a8e6-da7ef99137d5} 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af80b71 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af82f33 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002c64fc80 7. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1723: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr, unsigned long, std::shared_ptr, std::equal_to, std::allocator>>>, DB::MergeTreeData const&, std::vector> const&, std::shared_ptr, std::optional&, bool) @ 0x000000002de379fd 8. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1437: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000002de3554f 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:0: DB::ReadFromMergeTree::getAnalysisResult() const @ 0x000000002de41345 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:2022: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000002de4404c 11. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000002ddb933c 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000002ddff11e 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000002942117f 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x00000000294209e7 15. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b382fc 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 18. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 22. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:08:31.291054 [ 20345 ] {225ba941-9b99-4284-9113-a1643ccbf24d} executeQuery: Code: 42. DB::Exception: Number of arguments for function greatCircleAngle doesn't match: passed 2, should be 4: In scope SELECT greatCircleAngle(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT greatCircleAngle(NULL, NULL);) 2025.09.09 15:08:31.297848 [ 20345 ] {225ba941-9b99-4284-9113-a1643ccbf24d} TCPHandler: Code: 42. DB::Exception: Number of arguments for function greatCircleAngle doesn't match: passed 2, should be 4: In scope SELECT greatCircleAngle(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:08:31.341245 [ 20345 ] {8ada17ea-4910-41bf-b3f5-11c8537e9b0a} executeQuery: Code: 42. DB::Exception: Number of arguments for function greatCircleDistance doesn't match: passed 2, should be 4: In scope SELECT greatCircleDistance(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT greatCircleDistance(NULL, NULL);) 2025.09.09 15:08:31.344515 [ 20345 ] {8ada17ea-4910-41bf-b3f5-11c8537e9b0a} TCPHandler: Code: 42. DB::Exception: Number of arguments for function greatCircleDistance doesn't match: passed 2, should be 4: In scope SELECT greatCircleDistance(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:08:31.654548 [ 2804 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:08:32.059521 [ 2857 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:08:32.205652 [ 2802 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:08:32.212847 [ 2905 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:08:32.660024 [ 2913 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:08:33.062057 [ 2957 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:08:33.209363 [ 2981 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:08:33.215541 [ 2966 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:08:33.662307 [ 3010 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:08:33.960523 [ 20379 ] {ecaa46cb-c563-4f8c-8649-f11f48c6fa8f} 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.10505.altinitytest (altinity build)) (from [::1]:56432) (comment: 00700_decimal_aggregates.sql) (in query: SELECT median(a), median(b), median(c) as x, toTypeName(x) FROM decimal;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af819ed 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80746 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d34b5ca 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000002d3486e4 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000002d34827b 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002d36bcf7 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 12. asan_thread_start(void*) @ 0x000000000aa43059 13. ? @ 0x00007f35aab92ac3 14. ? @ 0x00007f35aac24850 2025.09.09 15:08:33.963032 [ 20379 ] {ecaa46cb-c563-4f8c-8649-f11f48c6fa8f} 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af819ed 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80746 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d34b5ca 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000002d3486e4 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000002d34827b 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002d36bcf7 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 12. asan_thread_start(void*) @ 0x000000000aa43059 13. ? @ 0x00007f35aab92ac3 14. ? @ 0x00007f35aac24850 2025.09.09 15:08:34.065379 [ 3078 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:08:34.212099 [ 3041 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:08:34.224315 [ 3090 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:08:34.472632 [ 3722 ] {c9eca937-315b-4f9c-8c9f-cb2ec187766c} executeQuery: Code: 43. DB::Exception: The timezone argument of function toMonday is allowed only when the 1st argument has the type DateTime or DateTime64: In scope SELECT toMonday(toDate(16433), 'Asia/Istanbul'). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:56446) (comment: 00189_time_zones_long.sql) (in query: SELECT toMonday(toDate(16433), 'Asia/Istanbul');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000aad4b34 4. DB::IFunctionDateOrDateTime::checkArguments(std::vector> const&, bool) const @ 0x000000001865aca3 5. DB::FunctionDateOrDateTimeToDateOrDate32::getReturnTypeImpl(std::vector> const&) const @ 0x000000001865521f 6. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000ccd376e 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000ccd3176 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000ccd4343 9. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000028399ff0 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000028367bce 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028366290 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283b62c9 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002835ae03 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000028359104 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000028357f0d 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002921bdcc 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&) @ 0x000000002941f313 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&) @ 0x0000000029419aef 19. ./contrib/llvm-project/libcxx/include/vector:432: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000029421f5d 20. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000029344c1b 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*) @ 0x0000000029b3703b 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 23. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 24. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 29. asan_thread_start(void*) @ 0x000000000aa43059 30. ? @ 0x00007f35aab92ac3 31. ? @ 0x00007f35aac24850 2025.09.09 15:08:34.518573 [ 3722 ] {c9eca937-315b-4f9c-8c9f-cb2ec187766c} TCPHandler: Code: 43. DB::Exception: The timezone argument of function toMonday is allowed only when the 1st argument has the type DateTime or DateTime64: In scope SELECT toMonday(toDate(16433), 'Asia/Istanbul'). (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000aad4b34 4. DB::IFunctionDateOrDateTime::checkArguments(std::vector> const&, bool) const @ 0x000000001865aca3 5. DB::FunctionDateOrDateTimeToDateOrDate32::getReturnTypeImpl(std::vector> const&) const @ 0x000000001865521f 6. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000ccd376e 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000ccd3176 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000ccd4343 9. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000028399ff0 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000028367bce 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028366290 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283b62c9 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002835ae03 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000028359104 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000028357f0d 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002921bdcc 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&) @ 0x000000002941f313 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&) @ 0x0000000029419aef 19. ./contrib/llvm-project/libcxx/include/vector:432: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000029421f5d 20. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000029344c1b 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*) @ 0x0000000029b3703b 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 23. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 24. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 29. asan_thread_start(void*) @ 0x000000000aa43059 30. ? @ 0x00007f35aab92ac3 31. ? @ 0x00007f35aac24850 2025.09.09 15:08:34.670917 [ 3085 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:08:34.706948 [ 20345 ] {12cb5ae9-9f96-4047-a32a-8986aaa749e6} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3CellAreaM2 doesn't match: passed 2, should be 1: In scope SELECT h3CellAreaM2(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT h3CellAreaM2(NULL, NULL);) 2025.09.09 15:08:34.715662 [ 20345 ] {12cb5ae9-9f96-4047-a32a-8986aaa749e6} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3CellAreaM2 doesn't match: passed 2, should be 1: In scope SELECT h3CellAreaM2(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:08:34.798632 [ 20345 ] {80b0cb3b-d4f4-493d-98ba-350b5b7ed8bd} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3CellAreaRads2 doesn't match: passed 2, should be 1: In scope SELECT h3CellAreaRads2(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT h3CellAreaRads2(NULL, NULL);) 2025.09.09 15:08:34.804995 [ 20345 ] {80b0cb3b-d4f4-493d-98ba-350b5b7ed8bd} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3CellAreaRads2 doesn't match: passed 2, should be 1: In scope SELECT h3CellAreaRads2(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:08:35.042857 [ 20345 ] {7b6f0b7f-78bb-4a17-998d-a5346b8f9e04} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3EdgeAngle doesn't match: passed 2, should be 1: In scope SELECT h3EdgeAngle(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT h3EdgeAngle(NULL, NULL);) 2025.09.09 15:08:35.045289 [ 20345 ] {7b6f0b7f-78bb-4a17-998d-a5346b8f9e04} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3EdgeAngle doesn't match: passed 2, should be 1: In scope SELECT h3EdgeAngle(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:08:35.067561 [ 3131 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:08:35.073452 [ 20345 ] {79e91a29-95b9-46af-acab-92a8d526b7cb} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3EdgeLengthKm doesn't match: passed 2, should be 1: In scope SELECT h3EdgeLengthKm(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT h3EdgeLengthKm(NULL, NULL);) 2025.09.09 15:08:35.077086 [ 20345 ] {79e91a29-95b9-46af-acab-92a8d526b7cb} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3EdgeLengthKm doesn't match: passed 2, should be 1: In scope SELECT h3EdgeLengthKm(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:08:35.203084 [ 20345 ] {66b8582e-95b9-45ae-b421-3a49b03f0a7e} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3EdgeLengthM doesn't match: passed 2, should be 1: In scope SELECT h3EdgeLengthM(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT h3EdgeLengthM(NULL, NULL);) 2025.09.09 15:08:35.205517 [ 20345 ] {66b8582e-95b9-45ae-b421-3a49b03f0a7e} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3EdgeLengthM doesn't match: passed 2, should be 1: In scope SELECT h3EdgeLengthM(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:08:35.214098 [ 3144 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:08:35.226538 [ 3125 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:08:35.276124 [ 20345 ] {db8624e2-f9dd-439b-a11f-e8a90d82b4a5} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3ExactEdgeLengthKm doesn't match: passed 2, should be 1: In scope SELECT h3ExactEdgeLengthKm(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT h3ExactEdgeLengthKm(NULL, NULL);) 2025.09.09 15:08:35.279136 [ 20345 ] {db8624e2-f9dd-439b-a11f-e8a90d82b4a5} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3ExactEdgeLengthKm doesn't match: passed 2, should be 1: In scope SELECT h3ExactEdgeLengthKm(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:08:35.310316 [ 20345 ] {e9b7bd52-2ef2-40d4-a5c5-aec2fadcc02b} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3ExactEdgeLengthM doesn't match: passed 2, should be 1: In scope SELECT h3ExactEdgeLengthM(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT h3ExactEdgeLengthM(NULL, NULL);) 2025.09.09 15:08:35.316934 [ 20345 ] {e9b7bd52-2ef2-40d4-a5c5-aec2fadcc02b} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3ExactEdgeLengthM doesn't match: passed 2, should be 1: In scope SELECT h3ExactEdgeLengthM(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:08:35.364545 [ 3722 ] {059cd404-a4b5-4646-8571-92f64cd5d664} executeQuery: Code: 43. DB::Exception: The timezone argument of function toStartOfWeek is allowed only when the 1st argument is DateTime or DateTime64.: In scope SELECT toStartOfWeek(toDate(16433), 0, 'Asia/Istanbul'). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:56446) (comment: 00189_time_zones_long.sql) (in query: SELECT toStartOfWeek(toDate(16433), 0, 'Asia/Istanbul');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000aad4b34 4. DB::IFunctionCustomWeek::checkArguments(std::vector> const&, bool, bool) const @ 0x00000000185de2f0 5. DB::FunctionCustomWeekToDateOrDate32::getReturnTypeImpl(std::vector> const&) const @ 0x00000000185d751d 6. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000ccd376e 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000ccd3176 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000ccd4343 9. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000028399ff0 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000028367bce 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028366290 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283b62c9 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002835ae03 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000028359104 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000028357f0d 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002921bdcc 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&) @ 0x000000002941f313 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&) @ 0x0000000029419aef 19. ./contrib/llvm-project/libcxx/include/vector:432: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000029421f5d 20. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000029344c1b 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*) @ 0x0000000029b3703b 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 23. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 24. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 29. asan_thread_start(void*) @ 0x000000000aa43059 30. ? @ 0x00007f35aab92ac3 31. ? @ 0x00007f35aac24850 2025.09.09 15:08:35.367642 [ 3722 ] {059cd404-a4b5-4646-8571-92f64cd5d664} TCPHandler: Code: 43. DB::Exception: The timezone argument of function toStartOfWeek is allowed only when the 1st argument is DateTime or DateTime64.: In scope SELECT toStartOfWeek(toDate(16433), 0, 'Asia/Istanbul'). (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000aad4b34 4. DB::IFunctionCustomWeek::checkArguments(std::vector> const&, bool, bool) const @ 0x00000000185de2f0 5. DB::FunctionCustomWeekToDateOrDate32::getReturnTypeImpl(std::vector> const&) const @ 0x00000000185d751d 6. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000ccd376e 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000ccd3176 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000ccd4343 9. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000028399ff0 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000028367bce 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028366290 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283b62c9 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002835ae03 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000028359104 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000028357f0d 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002921bdcc 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&) @ 0x000000002941f313 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&) @ 0x0000000029419aef 19. ./contrib/llvm-project/libcxx/include/vector:432: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000029421f5d 20. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000029344c1b 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*) @ 0x0000000029b3703b 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 23. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 24. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 29. asan_thread_start(void*) @ 0x000000000aa43059 30. ? @ 0x00007f35aab92ac3 31. ? @ 0x00007f35aac24850 2025.09.09 15:08:35.376440 [ 20345 ] {84c655ef-da68-4558-a673-9039af9cac04} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3ExactEdgeLengthRads doesn't match: passed 2, should be 1: In scope SELECT h3ExactEdgeLengthRads(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT h3ExactEdgeLengthRads(NULL, NULL);) 2025.09.09 15:08:35.379848 [ 20345 ] {84c655ef-da68-4558-a673-9039af9cac04} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3ExactEdgeLengthRads doesn't match: passed 2, should be 1: In scope SELECT h3ExactEdgeLengthRads(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:08:35.432173 [ 20345 ] {d528b9b3-e29b-4e24-b6c0-99172dce1bce} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3GetBaseCell doesn't match: passed 2, should be 1: In scope SELECT h3GetBaseCell(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT h3GetBaseCell(NULL, NULL);) 2025.09.09 15:08:35.434796 [ 20345 ] {d528b9b3-e29b-4e24-b6c0-99172dce1bce} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3GetBaseCell doesn't match: passed 2, should be 1: In scope SELECT h3GetBaseCell(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:08:35.483405 [ 20345 ] {9d6b4d9e-8e37-4456-87a4-56691a91e3ff} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3GetDestinationIndexFromUnidirectionalEdge doesn't match: passed 2, should be 1: In scope SELECT h3GetDestinationIndexFromUnidirectionalEdge(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT h3GetDestinationIndexFromUnidirectionalEdge(NULL, NULL);) 2025.09.09 15:08:35.488074 [ 20345 ] {9d6b4d9e-8e37-4456-87a4-56691a91e3ff} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3GetDestinationIndexFromUnidirectionalEdge doesn't match: passed 2, should be 1: In scope SELECT h3GetDestinationIndexFromUnidirectionalEdge(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:08:35.524900 [ 20345 ] {7856b5d3-7d28-4e76-8c81-7cc8e579a53f} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3GetFaces doesn't match: passed 2, should be 1: In scope SELECT h3GetFaces(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT h3GetFaces(NULL, NULL);) 2025.09.09 15:08:35.528143 [ 20345 ] {7856b5d3-7d28-4e76-8c81-7cc8e579a53f} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3GetFaces doesn't match: passed 2, should be 1: In scope SELECT h3GetFaces(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:08:35.570357 [ 20345 ] {0ecd732d-9d4c-4a5f-b78f-4972dba808a5} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3GetIndexesFromUnidirectionalEdge doesn't match: passed 2, should be 1: In scope SELECT h3GetIndexesFromUnidirectionalEdge(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT h3GetIndexesFromUnidirectionalEdge(NULL, NULL);) 2025.09.09 15:08:35.574583 [ 20345 ] {0ecd732d-9d4c-4a5f-b78f-4972dba808a5} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3GetIndexesFromUnidirectionalEdge doesn't match: passed 2, should be 1: In scope SELECT h3GetIndexesFromUnidirectionalEdge(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:08:35.669582 [ 20345 ] {3c69394f-0039-4e24-b38b-609c6c7299c7} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3GetOriginIndexFromUnidirectionalEdge doesn't match: passed 2, should be 1: In scope SELECT h3GetOriginIndexFromUnidirectionalEdge(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT h3GetOriginIndexFromUnidirectionalEdge(NULL, NULL);) 2025.09.09 15:08:35.673717 [ 3221 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:08:35.675041 [ 20345 ] {3c69394f-0039-4e24-b38b-609c6c7299c7} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3GetOriginIndexFromUnidirectionalEdge doesn't match: passed 2, should be 1: In scope SELECT h3GetOriginIndexFromUnidirectionalEdge(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:08:35.767011 [ 20345 ] {f53fc754-943b-42a2-b4e8-49b284605759} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3GetPentagonIndexes doesn't match: passed 2, should be 1: In scope SELECT h3GetPentagonIndexes(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT h3GetPentagonIndexes(NULL, NULL);) 2025.09.09 15:08:35.774484 [ 20345 ] {f53fc754-943b-42a2-b4e8-49b284605759} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3GetPentagonIndexes doesn't match: passed 2, should be 1: In scope SELECT h3GetPentagonIndexes(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:08:35.888025 [ 20345 ] {0935a6e8-4039-44a6-8226-b3498ce93b98} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3GetRes0Indexes doesn't match: passed 2, should be 0: In scope SELECT h3GetRes0Indexes(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT h3GetRes0Indexes(NULL, NULL);) 2025.09.09 15:08:35.896191 [ 20345 ] {0935a6e8-4039-44a6-8226-b3498ce93b98} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3GetRes0Indexes doesn't match: passed 2, should be 0: In scope SELECT h3GetRes0Indexes(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:08:36.000834 [ 20345 ] {3d2854f8-4094-405b-86aa-ae0507fd83da} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3GetResolution doesn't match: passed 2, should be 1: In scope SELECT h3GetResolution(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT h3GetResolution(NULL, NULL);) 2025.09.09 15:08:36.009179 [ 20345 ] {3d2854f8-4094-405b-86aa-ae0507fd83da} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3GetResolution doesn't match: passed 2, should be 1: In scope SELECT h3GetResolution(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:08:36.070896 [ 2742 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:08:36.217492 [ 3234 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:08:36.222801 [ 3722 ] {34895045-8580-4382-89f4-faf236347889} executeQuery: Code: 43. DB::Exception: The timezone argument of function toStartOfWeek is allowed only when the 1st argument is DateTime or DateTime64.: In scope SELECT toStartOfWeek(toDate(16433), 1, 'Asia/Istanbul'). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:56446) (comment: 00189_time_zones_long.sql) (in query: SELECT toStartOfWeek(toDate(16433), 1, 'Asia/Istanbul');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000aad4b34 4. DB::IFunctionCustomWeek::checkArguments(std::vector> const&, bool, bool) const @ 0x00000000185de2f0 5. DB::FunctionCustomWeekToDateOrDate32::getReturnTypeImpl(std::vector> const&) const @ 0x00000000185d751d 6. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000ccd376e 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000ccd3176 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000ccd4343 9. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000028399ff0 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000028367bce 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028366290 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283b62c9 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002835ae03 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000028359104 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000028357f0d 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002921bdcc 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&) @ 0x000000002941f313 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&) @ 0x0000000029419aef 19. ./contrib/llvm-project/libcxx/include/vector:432: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000029421f5d 20. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000029344c1b 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*) @ 0x0000000029b3703b 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 23. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 24. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 29. asan_thread_start(void*) @ 0x000000000aa43059 30. ? @ 0x00007f35aab92ac3 31. ? @ 0x00007f35aac24850 2025.09.09 15:08:36.225167 [ 3722 ] {34895045-8580-4382-89f4-faf236347889} TCPHandler: Code: 43. DB::Exception: The timezone argument of function toStartOfWeek is allowed only when the 1st argument is DateTime or DateTime64.: In scope SELECT toStartOfWeek(toDate(16433), 1, 'Asia/Istanbul'). (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000aad4b34 4. DB::IFunctionCustomWeek::checkArguments(std::vector> const&, bool, bool) const @ 0x00000000185de2f0 5. DB::FunctionCustomWeekToDateOrDate32::getReturnTypeImpl(std::vector> const&) const @ 0x00000000185d751d 6. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000ccd376e 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000ccd3176 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000ccd4343 9. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000028399ff0 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000028367bce 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028366290 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283b62c9 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002835ae03 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000028359104 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000028357f0d 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002921bdcc 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&) @ 0x000000002941f313 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&) @ 0x0000000029419aef 19. ./contrib/llvm-project/libcxx/include/vector:432: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000029421f5d 20. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000029344c1b 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*) @ 0x0000000029b3703b 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 23. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 24. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 29. asan_thread_start(void*) @ 0x000000000aa43059 30. ? @ 0x00007f35aab92ac3 31. ? @ 0x00007f35aac24850 2025.09.09 15:08:36.230343 [ 3154 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:08:36.306907 [ 20379 ] {502906a5-e736-4e89-8749-85ebe4abb917} executeQuery: Code: 158. DB::Exception: Limit for rows (controlled by 'max_rows_to_read' setting) exceeded, max rows: 900.00 thousand, current rows: 1.00 million. (TOO_MANY_ROWS) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:56466) (comment: 00971_merge_tree_uniform_read_distribution_and_max_rows_to_read.sql) (in query: -- constant ignore will be pruned by part pruner. ignore(*) is used. SELECT count() FROM merge_tree WHERE not ignore(*);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, String&&, String&&) @ 0x00000000278b34e0 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:24: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b3073 5. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:263: DB::ReadFromMergeTree::AnalysisResult::checkLimits(DB::Settings const&, DB::SelectQueryInfo const&) const @ 0x000000002de1b7f4 6. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:0: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000002de441af 7. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000002ddb933c 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000002ddff11e 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000002942117f 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x00000000294209e7 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b382fc 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 14. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 19. asan_thread_start(void*) @ 0x000000000aa43059 20. ? @ 0x00007f35aab92ac3 21. ? @ 0x00007f35aac24850 2025.09.09 15:08:36.317919 [ 20379 ] {502906a5-e736-4e89-8749-85ebe4abb917} TCPHandler: Code: 158. DB::Exception: Limit for rows (controlled by 'max_rows_to_read' setting) exceeded, max rows: 900.00 thousand, current rows: 1.00 million. (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, String&&, String&&) @ 0x00000000278b34e0 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:24: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b3073 5. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:263: DB::ReadFromMergeTree::AnalysisResult::checkLimits(DB::Settings const&, DB::SelectQueryInfo const&) const @ 0x000000002de1b7f4 6. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:0: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000002de441af 7. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000002ddb933c 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000002ddff11e 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000002942117f 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x00000000294209e7 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b382fc 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 14. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 19. asan_thread_start(void*) @ 0x000000000aa43059 20. ? @ 0x00007f35aab92ac3 21. ? @ 0x00007f35aac24850 2025.09.09 15:08:36.435934 [ 20379 ] {b7424736-2775-4b68-803c-50cbede75f65} executeQuery: Code: 158. DB::Exception: Limit for rows (controlled by 'max_rows_to_read' setting) exceeded, max rows: 900.00 thousand, current rows: 1.00 million. (TOO_MANY_ROWS) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:56466) (comment: 00971_merge_tree_uniform_read_distribution_and_max_rows_to_read.sql) (in query: SELECT count() FROM merge_tree WHERE not ignore(*);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, String&&, String&&) @ 0x00000000278b34e0 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:24: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b3073 5. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:263: DB::ReadFromMergeTree::AnalysisResult::checkLimits(DB::Settings const&, DB::SelectQueryInfo const&) const @ 0x000000002de1b7f4 6. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:0: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000002de441af 7. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000002ddb933c 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000002ddff11e 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000002942117f 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x00000000294209e7 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b382fc 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 14. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 19. asan_thread_start(void*) @ 0x000000000aa43059 20. ? @ 0x00007f35aab92ac3 21. ? @ 0x00007f35aac24850 2025.09.09 15:08:36.437907 [ 20345 ] {589f4107-cbcc-4159-b392-099f113050dc} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3GetUnidirectionalEdgeBoundary doesn't match: passed 2, should be 1: In scope SELECT h3GetUnidirectionalEdgeBoundary(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT h3GetUnidirectionalEdgeBoundary(NULL, NULL);) 2025.09.09 15:08:36.442274 [ 20379 ] {b7424736-2775-4b68-803c-50cbede75f65} TCPHandler: Code: 158. DB::Exception: Limit for rows (controlled by 'max_rows_to_read' setting) exceeded, max rows: 900.00 thousand, current rows: 1.00 million. (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, String&&, String&&) @ 0x00000000278b34e0 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:24: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b3073 5. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:263: DB::ReadFromMergeTree::AnalysisResult::checkLimits(DB::Settings const&, DB::SelectQueryInfo const&) const @ 0x000000002de1b7f4 6. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:0: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000002de441af 7. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000002ddb933c 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000002ddff11e 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000002942117f 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x00000000294209e7 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b382fc 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 14. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 19. asan_thread_start(void*) @ 0x000000000aa43059 20. ? @ 0x00007f35aab92ac3 21. ? @ 0x00007f35aac24850 2025.09.09 15:08:36.447948 [ 20345 ] {589f4107-cbcc-4159-b392-099f113050dc} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3GetUnidirectionalEdgeBoundary doesn't match: passed 2, should be 1: In scope SELECT h3GetUnidirectionalEdgeBoundary(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:08:36.557228 [ 20345 ] {cddb982b-c424-4a77-8f55-768cfd07a907} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3GetUnidirectionalEdgesFromHexagon doesn't match: passed 2, should be 1: In scope SELECT h3GetUnidirectionalEdgesFromHexagon(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT h3GetUnidirectionalEdgesFromHexagon(NULL, NULL);) 2025.09.09 15:08:36.559002 [ 20345 ] {cddb982b-c424-4a77-8f55-768cfd07a907} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3GetUnidirectionalEdgesFromHexagon doesn't match: passed 2, should be 1: In scope SELECT h3GetUnidirectionalEdgesFromHexagon(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:08:36.586508 [ 20345 ] {07a70669-e438-42cb-bc15-17846f202949} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3HexAreaKm2 doesn't match: passed 2, should be 1: In scope SELECT h3HexAreaKm2(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT h3HexAreaKm2(NULL, NULL);) 2025.09.09 15:08:36.597668 [ 20345 ] {07a70669-e438-42cb-bc15-17846f202949} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3HexAreaKm2 doesn't match: passed 2, should be 1: In scope SELECT h3HexAreaKm2(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:08:36.675797 [ 2778 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:08:36.690471 [ 20345 ] {4787d121-be6f-41c4-8358-16b87e79d83d} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3HexAreaM2 doesn't match: passed 2, should be 1: In scope SELECT h3HexAreaM2(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT h3HexAreaM2(NULL, NULL);) 2025.09.09 15:08:36.720171 [ 20345 ] {4787d121-be6f-41c4-8358-16b87e79d83d} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3HexAreaM2 doesn't match: passed 2, should be 1: In scope SELECT h3HexAreaM2(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:08:37.074409 [ 2798 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:08:37.183512 [ 20345 ] {1d52a9fa-09f0-4ed4-8a53-aea8187bea0f} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3IsPentagon doesn't match: passed 2, should be 1: In scope SELECT h3IsPentagon(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT h3IsPentagon(NULL, NULL);) 2025.09.09 15:08:37.195251 [ 20345 ] {1d52a9fa-09f0-4ed4-8a53-aea8187bea0f} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3IsPentagon doesn't match: passed 2, should be 1: In scope SELECT h3IsPentagon(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:08:37.220687 [ 2734 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:08:37.233430 [ 2832 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:08:37.291826 [ 20345 ] {9f3da894-4b5f-4171-b63f-2e0d8944c573} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3IsResClassIII doesn't match: passed 2, should be 1: In scope SELECT h3IsResClassIII(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT h3IsResClassIII(NULL, NULL);) 2025.09.09 15:08:37.305812 [ 20345 ] {9f3da894-4b5f-4171-b63f-2e0d8944c573} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3IsResClassIII doesn't match: passed 2, should be 1: In scope SELECT h3IsResClassIII(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:08:37.356579 [ 3722 ] {61f4a9c8-20f0-4620-9d66-b0e4ff467acb} executeQuery: Code: 43. DB::Exception: The timezone argument of function toLastDayOfWeek is allowed only when the 1st argument is DateTime or DateTime64.: In scope SELECT toLastDayOfWeek(toDate(16433), 0, 'Asia/Istanbul'). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:56446) (comment: 00189_time_zones_long.sql) (in query: SELECT toLastDayOfWeek(toDate(16433), 0, 'Asia/Istanbul');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000aad4b34 4. DB::IFunctionCustomWeek::checkArguments(std::vector> const&, bool, bool) const @ 0x00000000185e6f50 5. DB::FunctionCustomWeekToDateOrDate32::getReturnTypeImpl(std::vector> const&) const @ 0x00000000185e077d 6. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000ccd376e 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000ccd3176 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000ccd4343 9. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000028399ff0 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000028367bce 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028366290 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283b62c9 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002835ae03 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000028359104 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000028357f0d 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002921bdcc 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&) @ 0x000000002941f313 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&) @ 0x0000000029419aef 19. ./contrib/llvm-project/libcxx/include/vector:432: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000029421f5d 20. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000029344c1b 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*) @ 0x0000000029b3703b 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 23. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 24. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 29. asan_thread_start(void*) @ 0x000000000aa43059 30. ? @ 0x00007f35aab92ac3 31. ? @ 0x00007f35aac24850 2025.09.09 15:08:37.361897 [ 3722 ] {61f4a9c8-20f0-4620-9d66-b0e4ff467acb} TCPHandler: Code: 43. DB::Exception: The timezone argument of function toLastDayOfWeek is allowed only when the 1st argument is DateTime or DateTime64.: In scope SELECT toLastDayOfWeek(toDate(16433), 0, 'Asia/Istanbul'). (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000aad4b34 4. DB::IFunctionCustomWeek::checkArguments(std::vector> const&, bool, bool) const @ 0x00000000185e6f50 5. DB::FunctionCustomWeekToDateOrDate32::getReturnTypeImpl(std::vector> const&) const @ 0x00000000185e077d 6. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000ccd376e 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000ccd3176 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000ccd4343 9. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000028399ff0 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000028367bce 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028366290 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283b62c9 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002835ae03 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000028359104 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000028357f0d 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002921bdcc 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&) @ 0x000000002941f313 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&) @ 0x0000000029419aef 19. ./contrib/llvm-project/libcxx/include/vector:432: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000029421f5d 20. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000029344c1b 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*) @ 0x0000000029b3703b 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 23. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 24. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 29. asan_thread_start(void*) @ 0x000000000aa43059 30. ? @ 0x00007f35aab92ac3 31. ? @ 0x00007f35aac24850 2025.09.09 15:08:37.382002 [ 20345 ] {87a22a87-28a2-4f85-9fd4-574a1558a07a} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3IsValid doesn't match: passed 2, should be 1: In scope SELECT h3IsValid(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT h3IsValid(NULL, NULL);) 2025.09.09 15:08:37.402746 [ 20345 ] {87a22a87-28a2-4f85-9fd4-574a1558a07a} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3IsValid doesn't match: passed 2, should be 1: In scope SELECT h3IsValid(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:08:37.515405 [ 3728 ] {} 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. ./contrib/llvm-project/libcxx/include/string:1499: _ZN12Coordination9ExceptionC2IRA41_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x000000002cb2daa6 3. ./src/Common/ZooKeeper/IKeeper.h:509: _ZN12Coordination9Exception11fromMessageIRA41_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEES0_NS_5ErrorEOS5_ @ 0x000000002e6d1195 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1660: Coordination::ZooKeeper::maybeInjectRecvFault() @ 0x000000002e6c134a 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:0: Coordination::ZooKeeper::receiveEvent() @ 0x000000002e6bf27c 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:0: Coordination::ZooKeeper::receiveThread() @ 0x000000002e6be17c 7. ./src/Common/ThreadPool.h:312: 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*) @ 0x000000002e6ceaa7 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 10. asan_thread_start(void*) @ 0x000000000aa43059 11. ? @ 0x00007f35aab92ac3 12. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:08:37.524570 [ 2822 ] {} test_3.part_log_profile_events_r2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.09.09 15:08:37.529371 [ 2850 ] {} test_3.part_header_r2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.09.09 15:08:37.541549 [ 2821 ] {} test_3.part_header_r1 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.09.09 15:08:37.552445 [ 2823 ] {} test_3.part_log_profile_events_r1 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.09.09 15:08:37.556024 [ 2833 ] {} test_3.test_03217_merge_replica_2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.09.09 15:08:37.557630 [ 2864 ] {} test_3.src (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.09.09 15:08:37.560649 [ 2836 ] {} test_3.test_03217_merge_replica_1 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.09.09 15:08:37.563032 [ 2789 ] {} test_15.primary_key (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.09.09 15:08:37.566015 [ 2809 ] {} test_1.order_by_all (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.09.09 15:08:37.566982 [ 2817 ] {} test_3.part_header_r2 (ReplicatedMergeTreeCleanupThread): void DB::ReplicatedMergeTreeCleanupThread::run(): Code: 999. Coordination::Exception: Coordination error: Connection loss, path /clickhouse/tables/00814_replicated_minimalistic_part_header_zookeeper_test_3/test_00814/part_header/s1/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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: Coordination::Exception::Exception(Coordination::Error, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x00000000264863d9 4. ./src/Common/ZooKeeper/IKeeper.h:501: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x00000000264847c3 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:601: zkutil::ZooKeeper::existsWatch(String const&, Coordination::Stat*, std::function) @ 0x000000002e5f1707 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002e5ebc63 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:203: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x000000002ca16d1a 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x000000002ca15340 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:50: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x000000002ca13666 10. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 12. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 15. asan_thread_start(void*) @ 0x000000000aa43059 16. ? @ 0x00007f35aab92ac3 17. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:08:37.567995 [ 2810 ] {} test_3.part_header_r1 (ReplicatedMergeTreeCleanupThread): void DB::ReplicatedMergeTreeCleanupThread::run(): Code: 999. Coordination::Exception: Coordination error: Connection loss, path /clickhouse/tables/00814_replicated_minimalistic_part_header_zookeeper_test_3/test_00814/part_header/s1/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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: Coordination::Exception::Exception(Coordination::Error, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x00000000264863d9 4. ./src/Common/ZooKeeper/IKeeper.h:501: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x00000000264847c3 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:373: zkutil::ZooKeeper::tryGetChildrenWatch(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000002e5ea628 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:346: zkutil::ZooKeeper::tryGetChildren(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr const&, Coordination::ListRequestType) @ 0x000000002e5e9d09 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:514: DB::ReplicatedMergeTreeCleanupThread::getBlocksSortedByTime(String const&, zkutil::ZooKeeper&, std::vector>&, std::map, std::less, std::allocator>>>&) @ 0x000000002ca25d67 8. ./contrib/llvm-project/libcxx/include/vector:553: DB::ReplicatedMergeTreeCleanupThread::clearOldBlocks(String const&, unsigned long, unsigned long, std::map, std::less, std::allocator>>>&) @ 0x000000002ca1d797 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x000000002ca153d0 10. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:50: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x000000002ca13666 11. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 13. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 16. asan_thread_start(void*) @ 0x000000000aa43059 17. ? @ 0x00007f35aab92ac3 18. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:08:37.600445 [ 20345 ] {51d7f031-c3dd-4199-b79e-1e39cccc41f0} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3NumHexagons doesn't match: passed 2, should be 1: In scope SELECT h3NumHexagons(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT h3NumHexagons(NULL, NULL);) 2025.09.09 15:08:37.611724 [ 20345 ] {51d7f031-c3dd-4199-b79e-1e39cccc41f0} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3NumHexagons doesn't match: passed 2, should be 1: In scope SELECT h3NumHexagons(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:08:37.678657 [ 2875 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:08:37.748602 [ 20345 ] {4d32c33e-5b24-4195-95b0-bcb08888fbb5} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3PointDistKm doesn't match: passed 2, should be 4: In scope SELECT h3PointDistKm(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT h3PointDistKm(NULL, NULL);) 2025.09.09 15:08:37.756568 [ 20345 ] {4d32c33e-5b24-4195-95b0-bcb08888fbb5} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3PointDistKm doesn't match: passed 2, should be 4: In scope SELECT h3PointDistKm(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:08:37.935357 [ 20345 ] {97ca5027-35f0-4d9a-94de-e1d096277754} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3PointDistM doesn't match: passed 2, should be 4: In scope SELECT h3PointDistM(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT h3PointDistM(NULL, NULL);) 2025.09.09 15:08:37.939786 [ 20345 ] {97ca5027-35f0-4d9a-94de-e1d096277754} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3PointDistM doesn't match: passed 2, should be 4: In scope SELECT h3PointDistM(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:08:38.027117 [ 20345 ] {5dcad8c1-580b-4e4e-abaa-175c08cb872e} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3PointDistRads doesn't match: passed 2, should be 4: In scope SELECT h3PointDistRads(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT h3PointDistRads(NULL, NULL);) 2025.09.09 15:08:38.037994 [ 20345 ] {5dcad8c1-580b-4e4e-abaa-175c08cb872e} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3PointDistRads doesn't match: passed 2, should be 4: In scope SELECT h3PointDistRads(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:08:38.076675 [ 2857 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:08:38.228698 [ 2877 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:08:38.236380 [ 2896 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:08:38.279508 [ 3722 ] {9ed34da8-b6a2-4c2e-9912-a721cb8a2afa} executeQuery: Code: 43. DB::Exception: The timezone argument of function toLastDayOfWeek is allowed only when the 1st argument is DateTime or DateTime64.: In scope SELECT toLastDayOfWeek(toDate(16433), 1, 'Asia/Istanbul'). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:56446) (comment: 00189_time_zones_long.sql) (in query: SELECT toLastDayOfWeek(toDate(16433), 1, 'Asia/Istanbul');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000aad4b34 4. DB::IFunctionCustomWeek::checkArguments(std::vector> const&, bool, bool) const @ 0x00000000185e6f50 5. DB::FunctionCustomWeekToDateOrDate32::getReturnTypeImpl(std::vector> const&) const @ 0x00000000185e077d 6. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000ccd376e 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000ccd3176 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000ccd4343 9. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000028399ff0 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000028367bce 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028366290 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283b62c9 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002835ae03 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000028359104 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000028357f0d 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002921bdcc 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&) @ 0x000000002941f313 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&) @ 0x0000000029419aef 19. ./contrib/llvm-project/libcxx/include/vector:432: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000029421f5d 20. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000029344c1b 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*) @ 0x0000000029b3703b 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 23. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 24. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 29. asan_thread_start(void*) @ 0x000000000aa43059 30. ? @ 0x00007f35aab92ac3 31. ? @ 0x00007f35aac24850 2025.09.09 15:08:38.282066 [ 3722 ] {9ed34da8-b6a2-4c2e-9912-a721cb8a2afa} TCPHandler: Code: 43. DB::Exception: The timezone argument of function toLastDayOfWeek is allowed only when the 1st argument is DateTime or DateTime64.: In scope SELECT toLastDayOfWeek(toDate(16433), 1, 'Asia/Istanbul'). (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000aad4b34 4. DB::IFunctionCustomWeek::checkArguments(std::vector> const&, bool, bool) const @ 0x00000000185e6f50 5. DB::FunctionCustomWeekToDateOrDate32::getReturnTypeImpl(std::vector> const&) const @ 0x00000000185e077d 6. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000ccd376e 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000ccd3176 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000ccd4343 9. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000028399ff0 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000028367bce 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028366290 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283b62c9 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002835ae03 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000028359104 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000028357f0d 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002921bdcc 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&) @ 0x000000002941f313 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&) @ 0x0000000029419aef 19. ./contrib/llvm-project/libcxx/include/vector:432: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000029421f5d 20. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000029344c1b 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*) @ 0x0000000029b3703b 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 23. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 24. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 29. asan_thread_start(void*) @ 0x000000000aa43059 30. ? @ 0x00007f35aab92ac3 31. ? @ 0x00007f35aac24850 2025.09.09 15:08:38.333007 [ 20345 ] {071da548-5a3d-46e8-9086-7935a97f4bad} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3ToGeo doesn't match: passed 2, should be 1: In scope SELECT h3ToGeo(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT h3ToGeo(NULL, NULL);) 2025.09.09 15:08:38.338477 [ 20345 ] {071da548-5a3d-46e8-9086-7935a97f4bad} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3ToGeo doesn't match: passed 2, should be 1: In scope SELECT h3ToGeo(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:08:38.391827 [ 20345 ] {1e9b3dfd-0459-4798-843c-8277c77211ce} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3ToGeoBoundary doesn't match: passed 2, should be 1: In scope SELECT h3ToGeoBoundary(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT h3ToGeoBoundary(NULL, NULL);) 2025.09.09 15:08:38.393995 [ 20345 ] {1e9b3dfd-0459-4798-843c-8277c77211ce} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3ToGeoBoundary doesn't match: passed 2, should be 1: In scope SELECT h3ToGeoBoundary(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:08:38.514119 [ 20345 ] {939ff1a7-d3c5-4546-ae5c-4b8d08cb189a} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3ToString doesn't match: passed 2, should be 1: In scope SELECT h3ToString(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT h3ToString(NULL, NULL);) 2025.09.09 15:08:38.529992 [ 20345 ] {939ff1a7-d3c5-4546-ae5c-4b8d08cb189a} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3ToString doesn't match: passed 2, should be 1: In scope SELECT h3ToString(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:08:38.602989 [ 20345 ] {6f67fa74-a498-4009-aa40-b5f9b79a2e42} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3UnidirectionalEdgeIsValid doesn't match: passed 2, should be 1: In scope SELECT h3UnidirectionalEdgeIsValid(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT h3UnidirectionalEdgeIsValid(NULL, NULL);) 2025.09.09 15:08:38.609232 [ 20345 ] {6f67fa74-a498-4009-aa40-b5f9b79a2e42} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3UnidirectionalEdgeIsValid doesn't match: passed 2, should be 1: In scope SELECT h3UnidirectionalEdgeIsValid(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:08:38.681596 [ 2879 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:08:38.979663 [ 20345 ] {ca299b45-7bef-4f5c-84d4-930f1774f408} executeQuery: Code: 43. DB::Exception: First argument for function has must be an array or map. Actual Nullable(Nothing): In scope SELECT has(NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT has(NULL, NULL);) 2025.09.09 15:08:38.984813 [ 20345 ] {ca299b45-7bef-4f5c-84d4-930f1774f408} TCPHandler: Code: 43. DB::Exception: First argument for function has must be an array or map. Actual Nullable(Nothing): In scope SELECT has(NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.09.09 15:08:39.080080 [ 2952 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:08:39.233789 [ 2976 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:08:39.239866 [ 2990 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:08:39.591820 [ 3722 ] {c98b618a-c317-43b3-9810-361809585044} executeQuery: Code: 43. DB::Exception: The timezone argument of function toStartOfMonth is allowed only when the 1st argument has the type DateTime or DateTime64: In scope SELECT toStartOfMonth(toDate(16433), 'Asia/Istanbul'). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:56446) (comment: 00189_time_zones_long.sql) (in query: SELECT toStartOfMonth(toDate(16433), 'Asia/Istanbul');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000aad4b34 4. DB::IFunctionDateOrDateTime::checkArguments(std::vector> const&, bool) const @ 0x00000000186e4b83 5. DB::FunctionDateOrDateTimeToDateOrDate32::getReturnTypeImpl(std::vector> const&) const @ 0x00000000186df0df 6. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000ccd376e 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000ccd3176 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000ccd4343 9. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000028399ff0 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000028367bce 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028366290 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283b62c9 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002835ae03 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000028359104 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000028357f0d 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002921bdcc 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&) @ 0x000000002941f313 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&) @ 0x0000000029419aef 19. ./contrib/llvm-project/libcxx/include/vector:432: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000029421f5d 20. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000029344c1b 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*) @ 0x0000000029b3703b 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 23. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 24. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 29. asan_thread_start(void*) @ 0x000000000aa43059 30. ? @ 0x00007f35aab92ac3 31. ? @ 0x00007f35aac24850 2025.09.09 15:08:39.595834 [ 3722 ] {c98b618a-c317-43b3-9810-361809585044} TCPHandler: Code: 43. DB::Exception: The timezone argument of function toStartOfMonth is allowed only when the 1st argument has the type DateTime or DateTime64: In scope SELECT toStartOfMonth(toDate(16433), 'Asia/Istanbul'). (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000aad4b34 4. DB::IFunctionDateOrDateTime::checkArguments(std::vector> const&, bool) const @ 0x00000000186e4b83 5. DB::FunctionDateOrDateTimeToDateOrDate32::getReturnTypeImpl(std::vector> const&) const @ 0x00000000186df0df 6. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000ccd376e 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000ccd3176 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000ccd4343 9. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000028399ff0 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000028367bce 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028366290 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283b62c9 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002835ae03 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000028359104 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000028357f0d 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002921bdcc 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&) @ 0x000000002941f313 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&) @ 0x0000000029419aef 19. ./contrib/llvm-project/libcxx/include/vector:432: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000029421f5d 20. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000029344c1b 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*) @ 0x0000000029b3703b 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 23. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 24. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 29. asan_thread_start(void*) @ 0x000000000aa43059 30. ? @ 0x00007f35aab92ac3 31. ? @ 0x00007f35aac24850 2025.09.09 15:08:39.684330 [ 3003 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:08:40.082841 [ 3019 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:08:40.100985 [ 20345 ] {b3cabcfb-d702-41cb-9efa-a5762bbe57fb} executeQuery: Code: 42. DB::Exception: Number of arguments for function hasThreadFuzzer doesn't match: passed 2, should be 0: In scope SELECT hasThreadFuzzer(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT hasThreadFuzzer(NULL, NULL);) 2025.09.09 15:08:40.105426 [ 20345 ] {b3cabcfb-d702-41cb-9efa-a5762bbe57fb} TCPHandler: Code: 42. DB::Exception: Number of arguments for function hasThreadFuzzer doesn't match: passed 2, should be 0: In scope SELECT hasThreadFuzzer(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:08:40.236924 [ 3061 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:08:40.241903 [ 3078 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:08:40.285578 [ 3722 ] {4b02fb2a-129f-4da8-9cc3-e37e4b019287} executeQuery: Code: 43. DB::Exception: The timezone argument of function toStartOfQuarter is allowed only when the 1st argument has the type DateTime or DateTime64: In scope SELECT toStartOfQuarter(toDate(16343), 'Asia/Istanbul'). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:56446) (comment: 00189_time_zones_long.sql) (in query: SELECT toStartOfQuarter(toDate(16343), 'Asia/Istanbul');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000aad4b34 4. DB::IFunctionDateOrDateTime::checkArguments(std::vector> const&, bool) const @ 0x00000000186ed283 5. DB::FunctionDateOrDateTimeToDateOrDate32::getReturnTypeImpl(std::vector> const&) const @ 0x00000000186e6c3f 6. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000ccd376e 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000ccd3176 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000ccd4343 9. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000028399ff0 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000028367bce 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028366290 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283b62c9 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002835ae03 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000028359104 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000028357f0d 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002921bdcc 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&) @ 0x000000002941f313 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&) @ 0x0000000029419aef 19. ./contrib/llvm-project/libcxx/include/vector:432: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000029421f5d 20. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000029344c1b 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*) @ 0x0000000029b3703b 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 23. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 24. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 29. asan_thread_start(void*) @ 0x000000000aa43059 30. ? @ 0x00007f35aab92ac3 31. ? @ 0x00007f35aac24850 2025.09.09 15:08:40.287758 [ 3722 ] {4b02fb2a-129f-4da8-9cc3-e37e4b019287} TCPHandler: Code: 43. DB::Exception: The timezone argument of function toStartOfQuarter is allowed only when the 1st argument has the type DateTime or DateTime64: In scope SELECT toStartOfQuarter(toDate(16343), 'Asia/Istanbul'). (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000aad4b34 4. DB::IFunctionDateOrDateTime::checkArguments(std::vector> const&, bool) const @ 0x00000000186ed283 5. DB::FunctionDateOrDateTimeToDateOrDate32::getReturnTypeImpl(std::vector> const&) const @ 0x00000000186e6c3f 6. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000ccd376e 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000ccd3176 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000ccd4343 9. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000028399ff0 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000028367bce 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028366290 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283b62c9 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002835ae03 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000028359104 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000028357f0d 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002921bdcc 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&) @ 0x000000002941f313 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&) @ 0x0000000029419aef 19. ./contrib/llvm-project/libcxx/include/vector:432: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000029421f5d 20. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000029344c1b 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*) @ 0x0000000029b3703b 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 23. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 24. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 29. asan_thread_start(void*) @ 0x000000000aa43059 30. ? @ 0x00007f35aab92ac3 31. ? @ 0x00007f35aac24850 2025.09.09 15:08:40.623504 [ 20345 ] {be838cf4-40f0-45fe-ae3d-65f2e88876ef} executeQuery: Code: 42. DB::Exception: Number of arguments for function hex doesn't match: passed 2, should be 1: In scope SELECT hex(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT hex(NULL, NULL);) 2025.09.09 15:08:40.628539 [ 20345 ] {be838cf4-40f0-45fe-ae3d-65f2e88876ef} TCPHandler: Code: 42. DB::Exception: Number of arguments for function hex doesn't match: passed 2, should be 1: In scope SELECT hex(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:08:40.687480 [ 3067 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:08:41.085202 [ 3118 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:08:41.231890 [ 3722 ] {c44e8b6b-3614-45d7-9f46-fa39d8d7c706} executeQuery: Code: 43. DB::Exception: The timezone argument of function toStartOfYear is allowed only when the 1st argument has the type DateTime or DateTime64: In scope SELECT toStartOfYear(toDate(16433), 'Asia/Istanbul'). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:56446) (comment: 00189_time_zones_long.sql) (in query: SELECT toStartOfYear(toDate(16433), 'Asia/Istanbul');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000aad4b34 4. DB::IFunctionDateOrDateTime::checkArguments(std::vector> const&, bool) const @ 0x0000000018710903 5. DB::FunctionDateOrDateTimeToDateOrDate32::getReturnTypeImpl(std::vector> const&) const @ 0x000000001870a09f 6. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000ccd376e 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000ccd3176 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000ccd4343 9. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000028399ff0 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000028367bce 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028366290 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283b62c9 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002835ae03 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000028359104 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000028357f0d 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002921bdcc 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&) @ 0x000000002941f313 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&) @ 0x0000000029419aef 19. ./contrib/llvm-project/libcxx/include/vector:432: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000029421f5d 20. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000029344c1b 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*) @ 0x0000000029b3703b 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 23. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 24. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 29. asan_thread_start(void*) @ 0x000000000aa43059 30. ? @ 0x00007f35aab92ac3 31. ? @ 0x00007f35aac24850 2025.09.09 15:08:41.234736 [ 3722 ] {c44e8b6b-3614-45d7-9f46-fa39d8d7c706} TCPHandler: Code: 43. DB::Exception: The timezone argument of function toStartOfYear is allowed only when the 1st argument has the type DateTime or DateTime64: In scope SELECT toStartOfYear(toDate(16433), 'Asia/Istanbul'). (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000aad4b34 4. DB::IFunctionDateOrDateTime::checkArguments(std::vector> const&, bool) const @ 0x0000000018710903 5. DB::FunctionDateOrDateTimeToDateOrDate32::getReturnTypeImpl(std::vector> const&) const @ 0x000000001870a09f 6. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000ccd376e 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000ccd3176 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000ccd4343 9. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000028399ff0 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000028367bce 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028366290 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283b62c9 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002835ae03 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000028359104 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000028357f0d 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002921bdcc 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&) @ 0x000000002941f313 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&) @ 0x0000000029419aef 19. ./contrib/llvm-project/libcxx/include/vector:432: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000029421f5d 20. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000029344c1b 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*) @ 0x0000000029b3703b 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 23. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 24. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 29. asan_thread_start(void*) @ 0x000000000aa43059 30. ? @ 0x00007f35aab92ac3 31. ? @ 0x00007f35aac24850 2025.09.09 15:08:41.242685 [ 3116 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:08:41.244947 [ 3129 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:08:41.653174 [ 20345 ] {1eafb4b0-5f2e-4f29-bc01-8a2bceda8d26} executeQuery: Code: 42. DB::Exception: Number of arguments for function hostName doesn't match: passed 2, should be 0: In scope SELECT hostName(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT hostName(NULL, NULL);) 2025.09.09 15:08:41.657463 [ 20345 ] {1eafb4b0-5f2e-4f29-bc01-8a2bceda8d26} TCPHandler: Code: 42. DB::Exception: Number of arguments for function hostName doesn't match: passed 2, should be 0: In scope SELECT hostName(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:08:41.695655 [ 3130 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:08:41.711251 [ 20345 ] {fc5846c8-b404-4ba1-b924-43cfbda63d17} executeQuery: Code: 42. DB::Exception: Number of arguments for function hostName doesn't match: passed 2, should be 0: In scope SELECT hostname(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT hostname(NULL, NULL);) 2025.09.09 15:08:41.716702 [ 20345 ] {fc5846c8-b404-4ba1-b924-43cfbda63d17} TCPHandler: Code: 42. DB::Exception: Number of arguments for function hostName doesn't match: passed 2, should be 0: In scope SELECT hostname(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:08:41.870862 [ 20345 ] {a497d0a3-619c-4688-a4c0-a724d8d3ea88} executeQuery: Code: 42. DB::Exception: Number of arguments for function identity doesn't match: passed 2, should be 1: In scope SELECT identity(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT identity(NULL, NULL);) 2025.09.09 15:08:41.875398 [ 20345 ] {a497d0a3-619c-4688-a4c0-a724d8d3ea88} TCPHandler: Code: 42. DB::Exception: Number of arguments for function identity doesn't match: passed 2, should be 1: In scope SELECT identity(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:08:41.948915 [ 20345 ] {1eb889ec-1445-4441-a71f-4297df1b02f5} executeQuery: Code: 42. DB::Exception: Number of arguments for function idnaDecode doesn't match: passed 2, should be 1: In scope SELECT idnaDecode(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT idnaDecode(NULL, NULL);) 2025.09.09 15:08:42.031382 [ 20345 ] {1eb889ec-1445-4441-a71f-4297df1b02f5} TCPHandler: Code: 42. DB::Exception: Number of arguments for function idnaDecode doesn't match: passed 2, should be 1: In scope SELECT idnaDecode(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:08:42.088184 [ 3192 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:08:42.164279 [ 20345 ] {645430a6-1c69-4685-946f-64925f938c6f} executeQuery: Code: 42. DB::Exception: Number of arguments for function idnaEncode doesn't match: passed 2, should be 1: In scope SELECT idnaEncode(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT idnaEncode(NULL, NULL);) 2025.09.09 15:08:42.169038 [ 20345 ] {645430a6-1c69-4685-946f-64925f938c6f} TCPHandler: Code: 42. DB::Exception: Number of arguments for function idnaEncode doesn't match: passed 2, should be 1: In scope SELECT idnaEncode(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:08:42.220390 [ 20345 ] {979e11b2-f096-417c-9367-579c56fab7f8} executeQuery: Code: 42. DB::Exception: Number of arguments for function if doesn't match: passed 2, should be 3: In scope SELECT if(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT if(NULL, NULL);) 2025.09.09 15:08:42.225684 [ 20345 ] {979e11b2-f096-417c-9367-579c56fab7f8} TCPHandler: Code: 42. DB::Exception: Number of arguments for function if doesn't match: passed 2, should be 3: In scope SELECT if(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:08:42.247419 [ 3189 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:08:42.249724 [ 3221 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:08:42.390332 [ 19252 ] {77ca3e63-7ffc-4ad4-9078-b5cd0cf34b98} executeQuery: Code: 48. DB::Exception: MergeJoinAlgorithm is not implemented for strictness Semi. (NOT_IMPLEMENTED) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:56482) (comment: 00181_aggregate_functions_statistics_stable.sql) (in query: SELECT round(abs(COVAR1 - COVAR2), 6) FROM ( SELECT arrayJoin([1]) AS ID2, covarSampStable(x_value, y_value) AS COVAR1 FROM series ) ANY INNER JOIN ( SELECT arrayJoin([1]) AS ID2, sum(VAL) / (count() - 1) AS COVAR2 FROM ( SELECT (X - AVG_X) * (Y - AVG_Y) AS VAL FROM ( SELECT toUInt32(arrayJoin([1, 2, 3, 4, 5, 6, 7, 8, 9, 10])) AS ID, avg(x_value) AS AVG_X, avg(y_value) AS AVG_Y FROM series ) ANY INNER JOIN ( SELECT i AS ID, x_value AS X, y_value AS Y FROM series ) USING ID ) ) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::JoinStrictness&) @ 0x000000002da05174 4. ./build_docker/./src/Processors/Transforms/MergeJoinTransform.cpp:445: DB::MergeJoinAlgorithm::MergeJoinAlgorithm(DB::JoinKind, DB::JoinStrictness, DB::TableJoin::JoinOnClause const&, std::vector> const&, unsigned long) @ 0x000000002d9eeb05 5. ./build_docker/./src/Processors/Transforms/MergeJoinTransform.cpp:0: DB::MergeJoinAlgorithm::MergeJoinAlgorithm(std::shared_ptr, std::vector> const&, unsigned long) @ 0x000000002d9ef38d 6. ./src/Processors/Merges/IMergingTransform.h:166: DB::MergeJoinTransform::MergeJoinTransform(std::shared_ptr, std::vector> const&, DB::Block const&, unsigned long, unsigned long) @ 0x000000002da0369c 7. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:35: DB::QueryPipelineBuilder::joinPipelinesYShaped(std::unique_ptr>, std::unique_ptr>, std::shared_ptr, DB::Block const&, unsigned long, std::vector, std::allocator>>*) @ 0x000000002783e03e 8. ./build_docker/./src/Processors/QueryPlan/JoinStep.cpp:60: DB::JoinStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000002ddd4d41 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000002ddff11e 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000002942117f 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x00000000294209e7 12. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b382fc 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 15. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 19. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 20. asan_thread_start(void*) @ 0x000000000aa43059 21. ? @ 0x00007f35aab92ac3 22. ? @ 0x00007f35aac24850 2025.09.09 15:08:42.394741 [ 19252 ] {77ca3e63-7ffc-4ad4-9078-b5cd0cf34b98} TCPHandler: Code: 48. DB::Exception: MergeJoinAlgorithm is not implemented for strictness Semi. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::JoinStrictness&) @ 0x000000002da05174 4. ./build_docker/./src/Processors/Transforms/MergeJoinTransform.cpp:445: DB::MergeJoinAlgorithm::MergeJoinAlgorithm(DB::JoinKind, DB::JoinStrictness, DB::TableJoin::JoinOnClause const&, std::vector> const&, unsigned long) @ 0x000000002d9eeb05 5. ./build_docker/./src/Processors/Transforms/MergeJoinTransform.cpp:0: DB::MergeJoinAlgorithm::MergeJoinAlgorithm(std::shared_ptr, std::vector> const&, unsigned long) @ 0x000000002d9ef38d 6. ./src/Processors/Merges/IMergingTransform.h:166: DB::MergeJoinTransform::MergeJoinTransform(std::shared_ptr, std::vector> const&, DB::Block const&, unsigned long, unsigned long) @ 0x000000002da0369c 7. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:35: DB::QueryPipelineBuilder::joinPipelinesYShaped(std::unique_ptr>, std::unique_ptr>, std::shared_ptr, DB::Block const&, unsigned long, std::vector, std::allocator>>*) @ 0x000000002783e03e 8. ./build_docker/./src/Processors/QueryPlan/JoinStep.cpp:60: DB::JoinStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000002ddd4d41 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000002ddff11e 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000002942117f 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x00000000294209e7 12. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b382fc 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 15. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 19. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 20. asan_thread_start(void*) @ 0x000000000aa43059 21. ? @ 0x00007f35aab92ac3 22. ? @ 0x00007f35aac24850 2025.09.09 15:08:42.699270 [ 3234 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:08:43.091322 [ 3190 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:08:43.195217 [ 20345 ] {1a029869-926c-4caa-ac0f-f673bf8e7996} executeQuery: Code: 43. DB::Exception: First argument for function indexOf must be an array. Actual Nullable(Nothing): In scope SELECT indexOf(NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT indexOf(NULL, NULL);) 2025.09.09 15:08:43.201233 [ 20345 ] {1a029869-926c-4caa-ac0f-f673bf8e7996} TCPHandler: Code: 43. DB::Exception: First argument for function indexOf must be an array. Actual Nullable(Nothing): In scope SELECT indexOf(NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.09.09 15:08:43.254414 [ 3230 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:08:43.256066 [ 2748 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:08:43.344290 [ 20345 ] {98ba0b32-bdf4-46f8-8855-f5f438e92257} executeQuery: Code: 42. DB::Exception: Number of arguments for function initcap doesn't match: passed 2, should be 1: In scope SELECT initcap(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT initcap(NULL, NULL);) 2025.09.09 15:08:43.357859 [ 20345 ] {98ba0b32-bdf4-46f8-8855-f5f438e92257} TCPHandler: Code: 42. DB::Exception: Number of arguments for function initcap doesn't match: passed 2, should be 1: In scope SELECT initcap(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:08:43.433628 [ 20345 ] {fbdeed97-5f76-4b49-887b-9b3a8a3466b7} executeQuery: Code: 42. DB::Exception: Number of arguments for function initcapUTF8 doesn't match: passed 2, should be 1: In scope SELECT initcapUTF8(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT initcapUTF8(NULL, NULL);) 2025.09.09 15:08:43.467833 [ 20345 ] {fbdeed97-5f76-4b49-887b-9b3a8a3466b7} TCPHandler: Code: 42. DB::Exception: Number of arguments for function initcapUTF8 doesn't match: passed 2, should be 1: In scope SELECT initcapUTF8(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:08:43.559272 [ 20345 ] {44723a94-1959-4434-a4d4-172c5b54c3b6} executeQuery: Code: 42. DB::Exception: Number of arguments for function initialQueryID doesn't match: passed 2, should be 0: In scope SELECT initialQueryID(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT initialQueryID(NULL, NULL);) 2025.09.09 15:08:43.564608 [ 20345 ] {44723a94-1959-4434-a4d4-172c5b54c3b6} TCPHandler: Code: 42. DB::Exception: Number of arguments for function initialQueryID doesn't match: passed 2, should be 0: In scope SELECT initialQueryID(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:08:43.620832 [ 3335 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {44b09201-5a0e-4da3-91d1-ac60ea8508c5::202509_1_143_42}: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=13, 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af80b71 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80746 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002c765aab 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:1197: ? @ 0x000000002c7602b8 8. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x000000002c75fc2b 9. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:0: DB::MergeTreeReaderCompact::MergeTreeReaderCompact(std::shared_ptr, DB::NamesAndTypesList, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*, DB::MarkCache*, DB::MarkRanges, DB::MergeTreeReaderSettings, std::map, std::allocator>>, std::function const&, int) @ 0x000000002c7aee03 10. ./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.h:16: DB::MergeTreeReaderCompactSingleBuffer::MergeTreeReaderCompactSingleBuffer&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int&&) @ 0x000000002c5d6d21 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::MergeTreeDataPartCompact::getReader(DB::NamesAndTypesList const&, std::shared_ptr const&, DB::MarkRanges const&, std::unordered_map, std::equal_to, std::allocator>> const&, DB::UncompressedCache*, DB::MarkCache*, std::shared_ptr const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) const @ 0x000000002c5d1037 12. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:169: DB::MergeTreeSequentialSource::MergeTreeSequentialSource(DB::MergeTreeSequentialSourceType, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::vector>, std::optional, bool, bool, bool) @ 0x000000002c80c330 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:35: DB::MergeTreeSequentialSource* std::construct_at[abi:v15007] const&, std::shared_ptr&, std::shared_ptr&, std::vector>&, std::optional, bool, bool&, bool&, DB::MergeTreeSequentialSource*>(DB::MergeTreeSequentialSource*, DB::MergeTreeSequentialSourceType&, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr&, std::shared_ptr&, std::vector>&, std::optional&&, bool&&, bool&, bool&) @ 0x000000002c81320f 14. ./contrib/llvm-project/libcxx/include/__memory/allocator_traits.h:298: DB::createMergeTreeSequentialSource(DB::MergeTreeSequentialSourceType, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::vector>, std::optional, std::shared_ptr>, bool, bool, bool) @ 0x000000002c810812 15. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1136: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::createMergedStream() @ 0x000000002c3dd079 16. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() @ 0x000000002c3d6516 17. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:534: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x000000002c3e2799 18. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::execute() @ 0x000000002c3ef3fe 19. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:0: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000002cc2f4c0 20. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000002c427f28 21. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000002c429675 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7eaf0 23. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001af8a79f 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 26. asan_thread_start(void*) @ 0x000000000aa43059 27. ? @ 0x00007f35aab92ac3 28. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:08:43.695307 [ 20345 ] {6d853c7c-1c1a-4c17-915e-31d47250df06} executeQuery: Code: 42. DB::Exception: Number of arguments for function initialQueryID doesn't match: passed 2, should be 0: In scope SELECT initial_query_id(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT initial_query_id(NULL, NULL);) 2025.09.09 15:08:43.708911 [ 20345 ] {6d853c7c-1c1a-4c17-915e-31d47250df06} TCPHandler: Code: 42. DB::Exception: Number of arguments for function initialQueryID doesn't match: passed 2, should be 0: In scope SELECT initial_query_id(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:08:43.708986 [ 2813 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:08:43.777605 [ 20345 ] {ef50eeef-92df-46c6-9b49-74f46a4da2a3} executeQuery: Code: 43. DB::Exception: First argument for function initializeAggregation must be constant string: name of aggregate function.: In scope SELECT initializeAggregation(NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT initializeAggregation(NULL, NULL);) 2025.09.09 15:08:43.789677 [ 20345 ] {ef50eeef-92df-46c6-9b49-74f46a4da2a3} TCPHandler: Code: 43. DB::Exception: First argument for function initializeAggregation must be constant string: name of aggregate function.: In scope SELECT initializeAggregation(NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.09.09 15:08:44.094987 [ 2842 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:08:44.256837 [ 2812 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:08:44.258910 [ 2834 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:08:44.477332 [ 20345 ] {e5da8af6-f262-41a1-ab42-db76603b99bc} executeQuery: Code: 42. DB::Exception: Number of arguments for function intExp10 doesn't match: passed 2, should be 1: In scope SELECT intExp10(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT intExp10(NULL, NULL);) 2025.09.09 15:08:44.501963 [ 20345 ] {e5da8af6-f262-41a1-ab42-db76603b99bc} TCPHandler: Code: 42. DB::Exception: Number of arguments for function intExp10 doesn't match: passed 2, should be 1: In scope SELECT intExp10(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:08:44.595364 [ 20345 ] {9455a1df-05d1-4a98-8fd7-0ab8d264302e} executeQuery: Code: 42. DB::Exception: Number of arguments for function intExp2 doesn't match: passed 2, should be 1: In scope SELECT intExp2(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT intExp2(NULL, NULL);) 2025.09.09 15:08:44.615246 [ 20345 ] {9455a1df-05d1-4a98-8fd7-0ab8d264302e} TCPHandler: Code: 42. DB::Exception: Number of arguments for function intExp2 doesn't match: passed 2, should be 1: In scope SELECT intExp2(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:08:44.692153 [ 20345 ] {5e6ae712-9a3f-4a47-b885-d290f304199e} executeQuery: Code: 42. DB::Exception: Number of arguments for function intHash32 doesn't match: passed 2, should be 1: In scope SELECT intHash32(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT intHash32(NULL, NULL);) 2025.09.09 15:08:44.696392 [ 20345 ] {5e6ae712-9a3f-4a47-b885-d290f304199e} TCPHandler: Code: 42. DB::Exception: Number of arguments for function intHash32 doesn't match: passed 2, should be 1: In scope SELECT intHash32(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:08:44.711266 [ 2891 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:08:44.736957 [ 20345 ] {a300157a-c0a8-43ce-9f8a-14545656a545} executeQuery: Code: 42. DB::Exception: Number of arguments for function intHash64 doesn't match: passed 2, should be 1: In scope SELECT intHash64(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT intHash64(NULL, NULL);) 2025.09.09 15:08:44.739596 [ 20345 ] {a300157a-c0a8-43ce-9f8a-14545656a545} TCPHandler: Code: 42. DB::Exception: Number of arguments for function intHash64 doesn't match: passed 2, should be 1: In scope SELECT intHash64(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:08:45.009967 [ 20345 ] {7c6d97bd-15fd-44d2-bc2e-05e10b2d8aaa} executeQuery: Code: 42. DB::Exception: Number of arguments for function isConstant doesn't match: passed 2, should be 1: In scope SELECT isConstant(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT isConstant(NULL, NULL);) 2025.09.09 15:08:45.014015 [ 20345 ] {7c6d97bd-15fd-44d2-bc2e-05e10b2d8aaa} TCPHandler: Code: 42. DB::Exception: Number of arguments for function isConstant doesn't match: passed 2, should be 1: In scope SELECT isConstant(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:08:45.098511 [ 2890 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:08:45.259724 [ 2856 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:08:45.261687 [ 2926 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:08:45.394551 [ 20345 ] {9310b956-2692-4ed5-8b1b-97df4338a42f} executeQuery: Code: 42. DB::Exception: Number of arguments for function isDynamicElementInSharedData doesn't match: passed 2, should be 1: In scope SELECT isDynamicElementInSharedData(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT isDynamicElementInSharedData(NULL, NULL);) 2025.09.09 15:08:45.402167 [ 20345 ] {9310b956-2692-4ed5-8b1b-97df4338a42f} TCPHandler: Code: 42. DB::Exception: Number of arguments for function isDynamicElementInSharedData doesn't match: passed 2, should be 1: In scope SELECT isDynamicElementInSharedData(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:08:45.483047 [ 20345 ] {202d4088-dd9e-4a82-93fe-a542a5cd3055} executeQuery: Code: 42. DB::Exception: Number of arguments for function isFinite doesn't match: passed 2, should be 1: In scope SELECT isFinite(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT isFinite(NULL, NULL);) 2025.09.09 15:08:45.488881 [ 20345 ] {202d4088-dd9e-4a82-93fe-a542a5cd3055} TCPHandler: Code: 42. DB::Exception: Number of arguments for function isFinite doesn't match: passed 2, should be 1: In scope SELECT isFinite(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:08:45.571840 [ 20345 ] {5606cecf-28fd-45b0-b272-d3f1cb44fe8f} executeQuery: Code: 43. DB::Exception: The arguments of function isIPAddressInRange must be String: In scope SELECT isIPAddressInRange(NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT isIPAddressInRange(NULL, NULL);) 2025.09.09 15:08:45.577266 [ 20345 ] {5606cecf-28fd-45b0-b272-d3f1cb44fe8f} TCPHandler: Code: 43. DB::Exception: The arguments of function isIPAddressInRange must be String: In scope SELECT isIPAddressInRange(NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.09.09 15:08:45.671276 [ 20345 ] {1a72ac52-541c-420e-9435-58546d30d56a} executeQuery: Code: 42. DB::Exception: Number of arguments for function isIPv4String doesn't match: passed 2, should be 1: In scope SELECT isIPv4String(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT isIPv4String(NULL, NULL);) 2025.09.09 15:08:45.677114 [ 20345 ] {1a72ac52-541c-420e-9435-58546d30d56a} TCPHandler: Code: 42. DB::Exception: Number of arguments for function isIPv4String doesn't match: passed 2, should be 1: In scope SELECT isIPv4String(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:08:45.713820 [ 2940 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:08:45.743441 [ 20345 ] {c44a0330-34e7-4f6c-a492-eb9f551804a9} executeQuery: Code: 42. DB::Exception: Number of arguments for function isIPv6String doesn't match: passed 2, should be 1: In scope SELECT isIPv6String(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT isIPv6String(NULL, NULL);) 2025.09.09 15:08:45.758940 [ 20345 ] {c44a0330-34e7-4f6c-a492-eb9f551804a9} TCPHandler: Code: 42. DB::Exception: Number of arguments for function isIPv6String doesn't match: passed 2, should be 1: In scope SELECT isIPv6String(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:08:45.874594 [ 20345 ] {fd4466b5-35ee-4486-9968-39c53766f064} executeQuery: Code: 42. DB::Exception: Number of arguments for function isInfinite doesn't match: passed 2, should be 1: In scope SELECT isInfinite(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT isInfinite(NULL, NULL);) 2025.09.09 15:08:45.886640 [ 20345 ] {fd4466b5-35ee-4486-9968-39c53766f064} TCPHandler: Code: 42. DB::Exception: Number of arguments for function isInfinite doesn't match: passed 2, should be 1: In scope SELECT isInfinite(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:08:45.952152 [ 20345 ] {f8b2b461-c493-4011-af9f-d2acda4622b4} executeQuery: Code: 42. DB::Exception: Number of arguments for function isNaN doesn't match: passed 2, should be 1: In scope SELECT isNaN(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT isNaN(NULL, NULL);) 2025.09.09 15:08:45.955831 [ 20345 ] {f8b2b461-c493-4011-af9f-d2acda4622b4} TCPHandler: Code: 42. DB::Exception: Number of arguments for function isNaN doesn't match: passed 2, should be 1: In scope SELECT isNaN(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:08:46.024643 [ 20345 ] {43e17c08-636c-42b1-ba4d-ccd078e15ce8} executeQuery: Code: 48. DB::Exception: Function isNotDistinctFrom can be used only in the JOIN ON section: In scope SELECT NULL <=> NULL. (NOT_IMPLEMENTED) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT isNotDistinctFrom(NULL, NULL);) 2025.09.09 15:08:46.031444 [ 20345 ] {43e17c08-636c-42b1-ba4d-ccd078e15ce8} TCPHandler: Code: 48. DB::Exception: Function isNotDistinctFrom can be used only in the JOIN ON section: In scope SELECT NULL <=> NULL. (NOT_IMPLEMENTED) 2025.09.09 15:08:46.101859 [ 2988 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:08:46.109873 [ 20345 ] {01e25225-dad0-4324-873b-22b0a9af3043} executeQuery: Code: 42. DB::Exception: Number of arguments for function isNotNull doesn't match: passed 2, should be 1: In scope SELECT isNotNull(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT isNotNull(NULL, NULL);) 2025.09.09 15:08:46.118784 [ 20345 ] {01e25225-dad0-4324-873b-22b0a9af3043} TCPHandler: Code: 42. DB::Exception: Number of arguments for function isNotNull doesn't match: passed 2, should be 1: In scope SELECT isNotNull(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:08:46.262496 [ 2994 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:08:46.266430 [ 2984 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:08:46.271260 [ 20345 ] {50e086e7-cc0b-4772-a679-25dd4115081b} executeQuery: Code: 42. DB::Exception: Number of arguments for function isNull doesn't match: passed 2, should be 1: In scope SELECT isNull(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT isNull(NULL, NULL);) 2025.09.09 15:08:46.276547 [ 20345 ] {50e086e7-cc0b-4772-a679-25dd4115081b} TCPHandler: Code: 42. DB::Exception: Number of arguments for function isNull doesn't match: passed 2, should be 1: In scope SELECT isNull(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:08:46.494292 [ 20345 ] {7311f1c3-4c8c-42b0-9209-c88889938976} executeQuery: Code: 42. DB::Exception: Number of arguments for function isNullable doesn't match: passed 2, should be 1: In scope SELECT isNullable(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT isNullable(NULL, NULL);) 2025.09.09 15:08:46.504122 [ 20345 ] {7311f1c3-4c8c-42b0-9209-c88889938976} TCPHandler: Code: 42. DB::Exception: Number of arguments for function isNullable doesn't match: passed 2, should be 1: In scope SELECT isNullable(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:08:46.631512 [ 20345 ] {770e8b3a-fbeb-458c-b8b6-84d940f8af5f} executeQuery: Code: 42. DB::Exception: Function isValidJSON needs exactly one argument: In scope SELECT isValidJSON(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT isValidJSON(NULL, NULL);) 2025.09.09 15:08:46.635757 [ 20345 ] {770e8b3a-fbeb-458c-b8b6-84d940f8af5f} TCPHandler: Code: 42. DB::Exception: Function isValidJSON needs exactly one argument: In scope SELECT isValidJSON(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:08:46.708933 [ 20345 ] {b687d1a8-2a42-4d0e-bb4d-506d14b71b53} executeQuery: Code: 42. DB::Exception: Number of arguments for function isValidUTF8 doesn't match: passed 2, should be 1: In scope SELECT isValidUTF8(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT isValidUTF8(NULL, NULL);) 2025.09.09 15:08:46.716638 [ 3006 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:08:46.719438 [ 20345 ] {b687d1a8-2a42-4d0e-bb4d-506d14b71b53} TCPHandler: Code: 42. DB::Exception: Number of arguments for function isValidUTF8 doesn't match: passed 2, should be 1: In scope SELECT isValidUTF8(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:08:46.887763 [ 20345 ] {16de0d11-1884-4286-93e8-fb54fc4d2b70} executeQuery: Code: 42. DB::Exception: Number of arguments for function isZeroOrNull doesn't match: passed 2, should be 1: In scope SELECT isZeroOrNull(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT isZeroOrNull(NULL, NULL);) 2025.09.09 15:08:46.890742 [ 20345 ] {16de0d11-1884-4286-93e8-fb54fc4d2b70} TCPHandler: Code: 42. DB::Exception: Number of arguments for function isZeroOrNull doesn't match: passed 2, should be 1: In scope SELECT isZeroOrNull(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:08:47.105242 [ 3054 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:08:47.265698 [ 3007 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:08:47.269812 [ 3064 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:08:47.579809 [ 20345 ] {d633dd88-5454-4a84-b04a-9d491b899489} executeQuery: Code: 42. DB::Exception: Number of arguments for function 'joinGet' doesn't match: passed 2, should be greater or equal to 3: In scope SELECT joinGet(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT joinGet(NULL, NULL);) 2025.09.09 15:08:47.590632 [ 20345 ] {d633dd88-5454-4a84-b04a-9d491b899489} TCPHandler: Code: 42. DB::Exception: Number of arguments for function 'joinGet' doesn't match: passed 2, should be greater or equal to 3: In scope SELECT joinGet(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:08:47.703747 [ 20345 ] {7e35d872-0dfb-4959-a09b-f360d83e78f3} executeQuery: Code: 42. DB::Exception: Number of arguments for function 'joinGetOrNull' doesn't match: passed 2, should be greater or equal to 3: In scope SELECT joinGetOrNull(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT joinGetOrNull(NULL, NULL);) 2025.09.09 15:08:47.714875 [ 20345 ] {7e35d872-0dfb-4959-a09b-f360d83e78f3} TCPHandler: Code: 42. DB::Exception: Number of arguments for function 'joinGetOrNull' doesn't match: passed 2, should be greater or equal to 3: In scope SELECT joinGetOrNull(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:08:47.719388 [ 3112 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:08:48.107798 [ 3116 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:08:48.267845 [ 3122 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:08:48.272153 [ 3140 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:08:48.473133 [ 3722 ] {c43c8bd4-f6ad-4f97-b4de-4c07190f36be} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=790, jobs=739). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:56446) (comment: 00189_time_zones_long.sql) (in query: SELECT toString(toStartOfMinute(toDateTime(1549483055), 'Asia/Tokyo'), 'Asia/Tokyo');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af872f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af7b2d1 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af7c3f3 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d36920d 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000002d369e5f 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processOrdinaryQuery() @ 0x000000002d18af7b 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d17644a 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 15. asan_thread_start(void*) @ 0x000000000aa43059 16. ? @ 0x00007f35aab92ac3 17. ? @ 0x00007f35aac24850 2025.09.09 15:08:48.474350 [ 3722 ] {c43c8bd4-f6ad-4f97-b4de-4c07190f36be} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=790, 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af872f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af7b2d1 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af7c3f3 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d36920d 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000002d369e5f 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processOrdinaryQuery() @ 0x000000002d18af7b 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d17644a 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 15. asan_thread_start(void*) @ 0x000000000aa43059 16. ? @ 0x00007f35aab92ac3 17. ? @ 0x00007f35aac24850 2025.09.09 15:08:48.721542 [ 3175 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:08:48.938905 [ 3341 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {106d09da-5a03-4cbf-a443-a9d7490e42ad::202509_1_151_30}: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=13, jobs=0). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af80b71 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80746 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002c765aab 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:1197: ? @ 0x000000002c7602b8 8. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x000000002c75fc2b 9. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:0: DB::MergeTreeReaderCompact::MergeTreeReaderCompact(std::shared_ptr, DB::NamesAndTypesList, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*, DB::MarkCache*, DB::MarkRanges, DB::MergeTreeReaderSettings, std::map, std::allocator>>, std::function const&, int) @ 0x000000002c7aee03 10. ./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.h:16: DB::MergeTreeReaderCompactSingleBuffer::MergeTreeReaderCompactSingleBuffer&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int&&) @ 0x000000002c5d6d21 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::MergeTreeDataPartCompact::getReader(DB::NamesAndTypesList const&, std::shared_ptr const&, DB::MarkRanges const&, std::unordered_map, std::equal_to, std::allocator>> const&, DB::UncompressedCache*, DB::MarkCache*, std::shared_ptr const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) const @ 0x000000002c5d1037 12. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:169: DB::MergeTreeSequentialSource::MergeTreeSequentialSource(DB::MergeTreeSequentialSourceType, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::vector>, std::optional, bool, bool, bool) @ 0x000000002c80c330 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:35: DB::MergeTreeSequentialSource* std::construct_at[abi:v15007] const&, std::shared_ptr&, std::shared_ptr&, std::vector>&, std::optional, bool, bool&, bool&, DB::MergeTreeSequentialSource*>(DB::MergeTreeSequentialSource*, DB::MergeTreeSequentialSourceType&, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr&, std::shared_ptr&, std::vector>&, std::optional&&, bool&&, bool&, bool&) @ 0x000000002c81320f 14. ./contrib/llvm-project/libcxx/include/__memory/allocator_traits.h:298: DB::createMergeTreeSequentialSource(DB::MergeTreeSequentialSourceType, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::vector>, std::optional, std::shared_ptr>, bool, bool, bool) @ 0x000000002c810812 15. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1136: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::createMergedStream() @ 0x000000002c3dd079 16. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() @ 0x000000002c3d6516 17. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:534: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x000000002c3e2799 18. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::execute() @ 0x000000002c3ef3fe 19. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:0: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000002cc2f4c0 20. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000002c427f28 21. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000002c429675 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7eaf0 23. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001af8a79f 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 26. asan_thread_start(void*) @ 0x000000000aa43059 27. ? @ 0x00007f35aab92ac3 28. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:08:49.034663 [ 20345 ] {9485810f-5226-4f02-8d1f-06abc678ccc1} executeQuery: Code: 36. DB::Exception: Offset must be an integer, 'Nullable(Nothing)' given. (BAD_ARGUMENTS) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT lagInFrame(NULL, NULL);) 2025.09.09 15:08:49.051579 [ 20345 ] {9485810f-5226-4f02-8d1f-06abc678ccc1} TCPHandler: Code: 36. DB::Exception: Offset must be an integer, 'Nullable(Nothing)' given. (BAD_ARGUMENTS) 2025.09.09 15:08:49.109632 [ 3170 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:08:49.269266 [ 2732 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:08:49.273882 [ 3236 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:08:49.509542 [ 20345 ] {bff0d681-7501-422a-a86c-1c268ff34234} executeQuery: Code: 42. DB::Exception: Aggregate function anyLast_respect_nulls requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT last_value_respect_nulls(NULL, NULL);) 2025.09.09 15:08:49.511804 [ 20345 ] {bff0d681-7501-422a-a86c-1c268ff34234} TCPHandler: Code: 42. DB::Exception: Aggregate function anyLast_respect_nulls requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:08:49.682916 [ 20345 ] {a1f2c3dc-9383-43e0-9395-007403f803d4} executeQuery: Code: 42. DB::Exception: Number of arguments for function lower doesn't match: passed 2, should be 1: In scope SELECT lcase(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT lcase(NULL, NULL);) 2025.09.09 15:08:49.689437 [ 20345 ] {a1f2c3dc-9383-43e0-9395-007403f803d4} TCPHandler: Code: 42. DB::Exception: Number of arguments for function lower doesn't match: passed 2, should be 1: In scope SELECT lcase(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:08:49.724136 [ 2776 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:08:50.080163 [ 20345 ] {c17ca0c5-9a5d-4828-85b1-bc7e5c106abc} executeQuery: Code: 36. DB::Exception: Offset must be an integer, 'Nullable(Nothing)' given. (BAD_ARGUMENTS) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT leadInFrame(NULL, NULL);) 2025.09.09 15:08:50.086581 [ 20345 ] {c17ca0c5-9a5d-4828-85b1-bc7e5c106abc} TCPHandler: Code: 36. DB::Exception: Offset must be an integer, 'Nullable(Nothing)' given. (BAD_ARGUMENTS) 2025.09.09 15:08:50.112548 [ 2826 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:08:50.257968 [ 20849 ] {2ece2a8f-8ba4-4bfb-99ae-c75b3e06cba4} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=790, jobs=740). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:41300) (comment: 01922_sum_null_for_remote.sql) (in query: SELECT nothingNull(_CAST(NULL, 'Nullable(Nothing)')) AS `sum(NULL)` FROM `system`.`one` AS `__table1`), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af872f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af7b2d1 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af7c3f3 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d36920d 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000002d369e5f 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processOrdinaryQuery() @ 0x000000002d18af7b 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d17644a 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 15. asan_thread_start(void*) @ 0x000000000aa43059 16. ? @ 0x00007f35aab92ac3 17. ? @ 0x00007f35aac24850 2025.09.09 15:08:50.261785 [ 20849 ] {2ece2a8f-8ba4-4bfb-99ae-c75b3e06cba4} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=790, jobs=740). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af872f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af7b2d1 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af7c3f3 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d36920d 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000002d369e5f 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processOrdinaryQuery() @ 0x000000002d18af7b 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d17644a 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 15. asan_thread_start(void*) @ 0x000000000aa43059 16. ? @ 0x00007f35aab92ac3 17. ? @ 0x00007f35aac24850 2025.09.09 15:08:50.271770 [ 2825 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:08:50.281041 [ 2817 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:08:50.300566 [ 3722 ] {c67e8862-8083-40a0-a621-fcf67af5bcf9} executeQuery: Code: 439. DB::Exception: Received from 127.0.0.2:9000. DB::Exception: Cannot schedule a task: fault injected (threads=790, jobs=740). Stack trace: 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af872f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af7b2d1 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af7c3f3 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d36920d 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000002d369e5f 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processOrdinaryQuery() @ 0x000000002d18af7b 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d17644a 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 15. asan_thread_start(void*) @ 0x000000000aa43059 16. ? @ 0x00007f35aab92ac3 17. ? @ 0x00007f35aac24850 : While executing Remote. (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:58590) (comment: 01922_sum_null_for_remote.sql) (in query: select sum(null) from remote('127.0.0.{1,2}', 'system', 'one') ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. ./contrib/llvm-project/libcxx/include/string:1499: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x000000001aeb974e 3. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::Connection::receiveException() const @ 0x000000002cee6c6a 4. ./build_docker/./src/Client/Connection.cpp:0: DB::Connection::receivePacket() @ 0x000000002cef780e 5. ./build_docker/./src/Client/PacketReceiver.cpp:0: DB::PacketReceiver::Task::run(std::function, std::function) @ 0x000000002cf9767e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000278ab436 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000278aaa44 8. ./contrib/boost/boost/context/fiber_ucontext.hpp:82: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x00000000278a8394 2025.09.09 15:08:50.305210 [ 3722 ] {c67e8862-8083-40a0-a621-fcf67af5bcf9} TCPHandler: Code: 439. DB::Exception: Received from 127.0.0.2:9000. DB::Exception: Cannot schedule a task: fault injected (threads=790, jobs=740). Stack trace: 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af872f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af7b2d1 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af7c3f3 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d36920d 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000002d369e5f 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processOrdinaryQuery() @ 0x000000002d18af7b 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d17644a 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 15. asan_thread_start(void*) @ 0x000000000aa43059 16. ? @ 0x00007f35aab92ac3 17. ? @ 0x00007f35aac24850 : 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. ./contrib/llvm-project/libcxx/include/string:1499: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x000000001aeb974e 3. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::Connection::receiveException() const @ 0x000000002cee6c6a 4. ./build_docker/./src/Client/Connection.cpp:0: DB::Connection::receivePacket() @ 0x000000002cef780e 5. ./build_docker/./src/Client/PacketReceiver.cpp:0: DB::PacketReceiver::Task::run(std::function, std::function) @ 0x000000002cf9767e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000278ab436 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000278aaa44 8. ./contrib/boost/boost/context/fiber_ucontext.hpp:82: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x00000000278a8394 2025.09.09 15:08:50.726759 [ 2900 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:08:51.090243 [ 20345 ] {69b162d0-f595-49cc-a5f2-b6234b8b8f74} executeQuery: Code: 344. DB::Exception: Natural language processing function 'lemmatize' is experimental. Set `allow_experimental_nlp_functions` setting to enable it. (SUPPORT_IS_DISABLED) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT lemmatize(NULL, NULL);) 2025.09.09 15:08:51.106449 [ 20345 ] {69b162d0-f595-49cc-a5f2-b6234b8b8f74} TCPHandler: Code: 344. DB::Exception: Natural language processing function 'lemmatize' is experimental. Set `allow_experimental_nlp_functions` setting to enable it. (SUPPORT_IS_DISABLED) 2025.09.09 15:08:51.115163 [ 2823 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:08:51.212581 [ 3337 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {120a6b4f-0f93-4c7b-b7cc-46807ffa23fa::202509_1_160_32}: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=13, jobs=0). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af80b71 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80746 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002c765aab 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:1197: ? @ 0x000000002c7602b8 8. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x000000002c75fc2b 9. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:0: DB::MergeTreeReaderCompact::MergeTreeReaderCompact(std::shared_ptr, DB::NamesAndTypesList, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*, DB::MarkCache*, DB::MarkRanges, DB::MergeTreeReaderSettings, std::map, std::allocator>>, std::function const&, int) @ 0x000000002c7aee03 10. ./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.h:16: DB::MergeTreeReaderCompactSingleBuffer::MergeTreeReaderCompactSingleBuffer&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int&&) @ 0x000000002c5d6d21 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::MergeTreeDataPartCompact::getReader(DB::NamesAndTypesList const&, std::shared_ptr const&, DB::MarkRanges const&, std::unordered_map, std::equal_to, std::allocator>> const&, DB::UncompressedCache*, DB::MarkCache*, std::shared_ptr const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) const @ 0x000000002c5d1037 12. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:169: DB::MergeTreeSequentialSource::MergeTreeSequentialSource(DB::MergeTreeSequentialSourceType, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::vector>, std::optional, bool, bool, bool) @ 0x000000002c80c330 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:35: DB::MergeTreeSequentialSource* std::construct_at[abi:v15007] const&, std::shared_ptr&, std::shared_ptr&, std::vector>&, std::optional, bool, bool&, bool&, DB::MergeTreeSequentialSource*>(DB::MergeTreeSequentialSource*, DB::MergeTreeSequentialSourceType&, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr&, std::shared_ptr&, std::vector>&, std::optional&&, bool&&, bool&, bool&) @ 0x000000002c81320f 14. ./contrib/llvm-project/libcxx/include/__memory/allocator_traits.h:298: DB::createMergeTreeSequentialSource(DB::MergeTreeSequentialSourceType, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::vector>, std::optional, std::shared_ptr>, bool, bool, bool) @ 0x000000002c810812 15. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1136: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::createMergedStream() @ 0x000000002c3dd079 16. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() @ 0x000000002c3d6516 17. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:534: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x000000002c3e2799 18. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::execute() @ 0x000000002c3ef3fe 19. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:0: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000002cc2f4c0 20. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000002c427f28 21. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000002c429675 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7eaf0 23. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001af8a79f 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 26. asan_thread_start(void*) @ 0x000000000aa43059 27. ? @ 0x00007f35aab92ac3 28. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:08:51.221544 [ 20345 ] {9c7d55c5-99e9-4a7a-a0aa-c94adc00ce6a} executeQuery: Code: 42. DB::Exception: Number of arguments for function length doesn't match: passed 2, should be 1: In scope SELECT length(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT length(NULL, NULL);) 2025.09.09 15:08:51.229588 [ 20345 ] {9c7d55c5-99e9-4a7a-a0aa-c94adc00ce6a} TCPHandler: Code: 42. DB::Exception: Number of arguments for function length doesn't match: passed 2, should be 1: In scope SELECT length(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:08:51.292178 [ 2946 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:08:51.292638 [ 2913 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:08:51.367895 [ 20345 ] {daa9f891-7ebd-41f8-9420-42a9d27d52e7} executeQuery: Code: 42. DB::Exception: Number of arguments for function lengthUTF8 doesn't match: passed 2, should be 1: In scope SELECT lengthUTF8(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT lengthUTF8(NULL, NULL);) 2025.09.09 15:08:51.376883 [ 20345 ] {daa9f891-7ebd-41f8-9420-42a9d27d52e7} TCPHandler: Code: 42. DB::Exception: Number of arguments for function lengthUTF8 doesn't match: passed 2, should be 1: In scope SELECT lengthUTF8(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:08:51.728712 [ 2940 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:08:52.119533 [ 2990 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:08:52.294587 [ 2992 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:08:52.295016 [ 2998 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:08:52.440004 [ 20345 ] {48b14f73-4f5a-49a6-abc0-2439acd49d20} executeQuery: Code: 42. DB::Exception: Number of arguments for function lgamma doesn't match: passed 2, should be 1: In scope SELECT lgamma(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT lgamma(NULL, NULL);) 2025.09.09 15:08:52.444902 [ 20345 ] {48b14f73-4f5a-49a6-abc0-2439acd49d20} TCPHandler: Code: 42. DB::Exception: Number of arguments for function lgamma doesn't match: passed 2, should be 1: In scope SELECT lgamma(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:08:52.628347 [ 20345 ] {3f2a8ce7-788b-4a68-b6c2-adf29af1758b} executeQuery: Code: 42. DB::Exception: Number of arguments for function log doesn't match: passed 2, should be 1: In scope SELECT ln(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT ln(NULL, NULL);) 2025.09.09 15:08:52.647914 [ 20345 ] {3f2a8ce7-788b-4a68-b6c2-adf29af1758b} TCPHandler: Code: 42. DB::Exception: Number of arguments for function log doesn't match: passed 2, should be 1: In scope SELECT ln(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:08:52.731591 [ 3012 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:08:52.950125 [ 20345 ] {c0d8dce3-13e1-4196-b8bf-1fa6de332c11} executeQuery: Code: 42. DB::Exception: Number of arguments for function log doesn't match: passed 2, should be 1: In scope SELECT log(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT log(NULL, NULL);) 2025.09.09 15:08:52.957842 [ 20345 ] {c0d8dce3-13e1-4196-b8bf-1fa6de332c11} TCPHandler: Code: 42. DB::Exception: Number of arguments for function log doesn't match: passed 2, should be 1: In scope SELECT log(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:08:53.016463 [ 20345 ] {07f10469-7ea3-4841-82a6-b9747833ce08} executeQuery: Code: 42. DB::Exception: Number of arguments for function log10 doesn't match: passed 2, should be 1: In scope SELECT log10(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT log10(NULL, NULL);) 2025.09.09 15:08:53.022500 [ 20345 ] {07f10469-7ea3-4841-82a6-b9747833ce08} TCPHandler: Code: 42. DB::Exception: Number of arguments for function log10 doesn't match: passed 2, should be 1: In scope SELECT log10(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:08:53.079966 [ 20345 ] {97d12b89-9260-489f-84b2-a88e5a285927} executeQuery: Code: 42. DB::Exception: Number of arguments for function log1p doesn't match: passed 2, should be 1: In scope SELECT log1p(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT log1p(NULL, NULL);) 2025.09.09 15:08:53.097856 [ 20345 ] {97d12b89-9260-489f-84b2-a88e5a285927} TCPHandler: Code: 42. DB::Exception: Number of arguments for function log1p doesn't match: passed 2, should be 1: In scope SELECT log1p(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:08:53.121529 [ 3038 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:08:53.157171 [ 20345 ] {8ce93fb5-c40e-4dd0-aaa1-a20d995a5343} executeQuery: Code: 42. DB::Exception: Number of arguments for function log2 doesn't match: passed 2, should be 1: In scope SELECT log2(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT log2(NULL, NULL);) 2025.09.09 15:08:53.161176 [ 20345 ] {8ce93fb5-c40e-4dd0-aaa1-a20d995a5343} TCPHandler: Code: 42. DB::Exception: Number of arguments for function log2 doesn't match: passed 2, should be 1: In scope SELECT log2(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:08:53.235052 [ 20345 ] {ebcc1c33-b140-4641-b56c-4d283d0e19a9} executeQuery: Code: 42. DB::Exception: Number of arguments for function logTrace doesn't match: passed 2, should be 1: In scope SELECT logTrace(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT logTrace(NULL, NULL);) 2025.09.09 15:08:53.253879 [ 20345 ] {ebcc1c33-b140-4641-b56c-4d283d0e19a9} TCPHandler: Code: 42. DB::Exception: Number of arguments for function logTrace doesn't match: passed 2, should be 1: In scope SELECT logTrace(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:08:53.296281 [ 3074 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:08:53.296764 [ 3072 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:08:53.301631 [ 20345 ] {2ee9235f-406d-462f-809f-7562daa0d12d} executeQuery: Code: 42. DB::Exception: Number of arguments for function lowCardinalityIndices doesn't match: passed 2, should be 1: In scope SELECT lowCardinalityIndices(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT lowCardinalityIndices(NULL, NULL);) 2025.09.09 15:08:53.310128 [ 20345 ] {2ee9235f-406d-462f-809f-7562daa0d12d} TCPHandler: Code: 42. DB::Exception: Number of arguments for function lowCardinalityIndices doesn't match: passed 2, should be 1: In scope SELECT lowCardinalityIndices(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:08:53.352777 [ 20345 ] {693a27c0-955c-45aa-8e78-fa9febcfc101} executeQuery: Code: 42. DB::Exception: Number of arguments for function lowCardinalityKeys doesn't match: passed 2, should be 1: In scope SELECT lowCardinalityKeys(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT lowCardinalityKeys(NULL, NULL);) 2025.09.09 15:08:53.396119 [ 20345 ] {693a27c0-955c-45aa-8e78-fa9febcfc101} TCPHandler: Code: 42. DB::Exception: Number of arguments for function lowCardinalityKeys doesn't match: passed 2, should be 1: In scope SELECT lowCardinalityKeys(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:08:53.453501 [ 20345 ] {93c161e9-800b-409b-88b1-0847b47eec55} executeQuery: Code: 42. DB::Exception: Number of arguments for function lower doesn't match: passed 2, should be 1: In scope SELECT lower(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT lower(NULL, NULL);) 2025.09.09 15:08:53.458643 [ 20345 ] {93c161e9-800b-409b-88b1-0847b47eec55} TCPHandler: Code: 42. DB::Exception: Number of arguments for function lower doesn't match: passed 2, should be 1: In scope SELECT lower(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:08:53.496945 [ 20345 ] {5d17abd2-af5c-4363-a218-996a952356af} executeQuery: Code: 42. DB::Exception: Number of arguments for function lowerUTF8 doesn't match: passed 2, should be 1: In scope SELECT lowerUTF8(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT lowerUTF8(NULL, NULL);) 2025.09.09 15:08:53.499849 [ 20345 ] {5d17abd2-af5c-4363-a218-996a952356af} TCPHandler: Code: 42. DB::Exception: Number of arguments for function lowerUTF8 doesn't match: passed 2, should be 1: In scope SELECT lowerUTF8(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:08:53.733720 [ 3099 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:08:53.886050 [ 19252 ] {2703c831-ae86-4025-a924-cc857a3e9572} executeQuery: Code: 481. DB::Exception: SQLite database file path '/etc/passwd' must be inside 'user_files' directory. (PATH_ACCESS_DENIED) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:58592) (comment: 02918_sqlite_path_check.sh) (in query: Select * from sqlite('/etc/passwd', 'something');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::createDeprecated(String const&, int, bool) @ 0x000000000aaee710 3. ./build_docker/./src/Databases/SQLite/SQLiteUtils.cpp:22: DB::processSQLiteError(String const&, bool) @ 0x000000002660a46e 4. ./contrib/llvm-project/libcxx/include/string:1499: DB::validateSQLiteDatabasePath(String const&, String const&, bool, bool) @ 0x000000002660b36e 5. ./build_docker/./src/Databases/SQLite/SQLiteUtils.cpp:0: DB::openSQLiteDB(String const&, std::shared_ptr, bool) @ 0x000000002660bdf6 6. ./build_docker/./src/TableFunctions/TableFunctionSQLite.cpp:91: DB::(anonymous namespace)::TableFunctionSQLite::parseArguments(std::shared_ptr const&, std::shared_ptr) @ 0x0000000026034738 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000002836cae2 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000283ba404 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002835ad09 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000028359104 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000028357f0d 12. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002921bdcc 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002941f313 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000029419aef 15. ./contrib/llvm-project/libcxx/include/vector:432: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000029421f5d 16. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000029344c1b 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3703b 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 20. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 24. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 25. asan_thread_start(void*) @ 0x000000000aa43059 26. ? @ 0x00007f35aab92ac3 27. ? @ 0x00007f35aac24850 2025.09.09 15:08:53.899378 [ 19252 ] {2703c831-ae86-4025-a924-cc857a3e9572} TCPHandler: Code: 481. DB::Exception: SQLite database file path '/etc/passwd' must be inside 'user_files' directory. (PATH_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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::createDeprecated(String const&, int, bool) @ 0x000000000aaee710 3. ./build_docker/./src/Databases/SQLite/SQLiteUtils.cpp:22: DB::processSQLiteError(String const&, bool) @ 0x000000002660a46e 4. ./contrib/llvm-project/libcxx/include/string:1499: DB::validateSQLiteDatabasePath(String const&, String const&, bool, bool) @ 0x000000002660b36e 5. ./build_docker/./src/Databases/SQLite/SQLiteUtils.cpp:0: DB::openSQLiteDB(String const&, std::shared_ptr, bool) @ 0x000000002660bdf6 6. ./build_docker/./src/TableFunctions/TableFunctionSQLite.cpp:91: DB::(anonymous namespace)::TableFunctionSQLite::parseArguments(std::shared_ptr const&, std::shared_ptr) @ 0x0000000026034738 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000002836cae2 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000283ba404 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002835ad09 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000028359104 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000028357f0d 12. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002921bdcc 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002941f313 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000029419aef 15. ./contrib/llvm-project/libcxx/include/vector:432: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000029421f5d 16. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000029344c1b 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3703b 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 20. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 24. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 25. asan_thread_start(void*) @ 0x000000000aa43059 26. ? @ 0x00007f35aab92ac3 27. ? @ 0x00007f35aac24850 2025.09.09 15:08:54.123345 [ 3141 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:08:54.125387 [ 20345 ] {5b52e028-a8c5-4b9d-9731-09f33df42fdb} executeQuery: Code: 36. DB::Exception: Map cannot have a key of type Nullable(Nothing): In scope SELECT map(NULL, NULL). (BAD_ARGUMENTS) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT map(NULL, NULL);) 2025.09.09 15:08:54.129013 [ 20345 ] {5b52e028-a8c5-4b9d-9731-09f33df42fdb} TCPHandler: Code: 36. DB::Exception: Map cannot have a key of type Nullable(Nothing): In scope SELECT map(NULL, NULL). (BAD_ARGUMENTS) 2025.09.09 15:08:54.298048 [ 3173 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:08:54.298708 [ 3186 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:08:54.460882 [ 19252 ] {200ac2a5-28ab-499b-b79c-abb2244d286b} executeQuery: Code: 481. DB::Exception: SQLite database file path '../../../../etc/passwd' must be inside 'user_files' directory. (PATH_ACCESS_DENIED) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:58608) (comment: 02918_sqlite_path_check.sh) (in query: Select * from sqlite('../../../../etc/passwd', 'something');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::createDeprecated(String const&, int, bool) @ 0x000000000aaee710 3. ./build_docker/./src/Databases/SQLite/SQLiteUtils.cpp:22: DB::processSQLiteError(String const&, bool) @ 0x000000002660a46e 4. ./contrib/llvm-project/libcxx/include/string:1499: DB::validateSQLiteDatabasePath(String const&, String const&, bool, bool) @ 0x000000002660b36e 5. ./build_docker/./src/Databases/SQLite/SQLiteUtils.cpp:0: DB::openSQLiteDB(String const&, std::shared_ptr, bool) @ 0x000000002660bdf6 6. ./build_docker/./src/TableFunctions/TableFunctionSQLite.cpp:91: DB::(anonymous namespace)::TableFunctionSQLite::parseArguments(std::shared_ptr const&, std::shared_ptr) @ 0x0000000026034738 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000002836cae2 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000283ba404 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002835ad09 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000028359104 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000028357f0d 12. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002921bdcc 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002941f313 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000029419aef 15. ./contrib/llvm-project/libcxx/include/vector:432: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000029421f5d 16. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000029344c1b 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3703b 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 20. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 24. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 25. asan_thread_start(void*) @ 0x000000000aa43059 26. ? @ 0x00007f35aab92ac3 27. ? @ 0x00007f35aac24850 2025.09.09 15:08:54.470778 [ 19252 ] {200ac2a5-28ab-499b-b79c-abb2244d286b} TCPHandler: Code: 481. DB::Exception: SQLite database file path '../../../../etc/passwd' must be inside 'user_files' directory. (PATH_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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::createDeprecated(String const&, int, bool) @ 0x000000000aaee710 3. ./build_docker/./src/Databases/SQLite/SQLiteUtils.cpp:22: DB::processSQLiteError(String const&, bool) @ 0x000000002660a46e 4. ./contrib/llvm-project/libcxx/include/string:1499: DB::validateSQLiteDatabasePath(String const&, String const&, bool, bool) @ 0x000000002660b36e 5. ./build_docker/./src/Databases/SQLite/SQLiteUtils.cpp:0: DB::openSQLiteDB(String const&, std::shared_ptr, bool) @ 0x000000002660bdf6 6. ./build_docker/./src/TableFunctions/TableFunctionSQLite.cpp:91: DB::(anonymous namespace)::TableFunctionSQLite::parseArguments(std::shared_ptr const&, std::shared_ptr) @ 0x0000000026034738 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000002836cae2 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000283ba404 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002835ad09 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000028359104 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000028357f0d 12. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002921bdcc 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002941f313 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000029419aef 15. ./contrib/llvm-project/libcxx/include/vector:432: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000029421f5d 16. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000029344c1b 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3703b 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 20. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 24. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 25. asan_thread_start(void*) @ 0x000000000aa43059 26. ? @ 0x00007f35aab92ac3 27. ? @ 0x00007f35aac24850 2025.09.09 15:08:54.530906 [ 20345 ] {17959b64-5dab-485a-a281-759ec0b60350} executeQuery: Code: 43. DB::Exception: Function mapContains requires at least one argument of type Map: In scope SELECT mapContains(NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT mapContains(NULL, NULL);) 2025.09.09 15:08:54.533643 [ 20345 ] {17959b64-5dab-485a-a281-759ec0b60350} TCPHandler: Code: 43. DB::Exception: Function mapContains requires at least one argument of type Map: In scope SELECT mapContains(NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.09.09 15:08:54.735925 [ 3242 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:08:54.991468 [ 20345 ] {7bae78ed-edd1-42b3-881f-f64c77a0a5c7} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=790, jobs=741). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT mapExtractKeyLike(NULL, NULL);) 2025.09.09 15:08:54.994012 [ 20345 ] {7bae78ed-edd1-42b3-881f-f64c77a0a5c7} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=790, jobs=741). (CANNOT_SCHEDULE_TASK) 2025.09.09 15:08:55.125080 [ 2748 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:08:55.275253 [ 20345 ] {c1e45451-99e0-4257-9fed-f239745d4345} executeQuery: Code: 43. DB::Exception: Arguments of function mapFromArrays must be Array or Map, but Nullable(Nothing) is given: In scope SELECT mapFromArrays(NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT mapFromArrays(NULL, NULL);) 2025.09.09 15:08:55.276925 [ 20345 ] {c1e45451-99e0-4257-9fed-f239745d4345} TCPHandler: Code: 43. DB::Exception: Arguments of function mapFromArrays must be Array or Map, but Nullable(Nothing) is given: In scope SELECT mapFromArrays(NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.09.09 15:08:55.299755 [ 2776 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:08:55.308002 [ 2779 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:08:55.416163 [ 20345 ] {056bb311-ffb2-4ba4-977d-235afd6594a1} executeQuery: Code: 42. DB::Exception: Number of arguments for function mapKeys doesn't match: passed 2, should be 1: In scope SELECT mapKeys(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT mapKeys(NULL, NULL);) 2025.09.09 15:08:55.422561 [ 20345 ] {056bb311-ffb2-4ba4-977d-235afd6594a1} TCPHandler: Code: 42. DB::Exception: Number of arguments for function mapKeys doesn't match: passed 2, should be 1: In scope SELECT mapKeys(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:08:55.743290 [ 2786 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:08:56.127576 [ 2862 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:08:56.301953 [ 2802 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:08:56.310447 [ 2899 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:08:56.469181 [ 20345 ] {3860581a-4a5b-44d6-95e2-3332eea334ed} executeQuery: Code: 42. DB::Exception: Number of arguments for function mapValues doesn't match: passed 2, should be 1: In scope SELECT mapValues(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT mapValues(NULL, NULL);) 2025.09.09 15:08:56.479399 [ 20345 ] {3860581a-4a5b-44d6-95e2-3332eea334ed} TCPHandler: Code: 42. DB::Exception: Number of arguments for function mapValues doesn't match: passed 2, should be 1: In scope SELECT mapValues(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:08:56.745838 [ 2850 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:08:56.827382 [ 20345 ] {4cb93173-254e-4ba5-b434-f34a190ba528} executeQuery: Code: 42. DB::Exception: Number of arguments for function materialize doesn't match: passed 2, should be 1: In scope SELECT materialize(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT materialize(NULL, NULL);) 2025.09.09 15:08:56.842017 [ 20345 ] {4cb93173-254e-4ba5-b434-f34a190ba528} TCPHandler: Code: 42. DB::Exception: Number of arguments for function materialize doesn't match: passed 2, should be 1: In scope SELECT materialize(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:08:57.130538 [ 2873 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:08:57.305051 [ 2879 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:08:57.313792 [ 2914 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:08:57.748840 [ 2942 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:08:58.160325 [ 2994 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:08:58.308365 [ 2992 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:08:58.316613 [ 2962 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:08:58.751265 [ 3057 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:08:58.789604 [ 20379 ] {ae5f8504-0381-4b25-8a4e-0f892cea2efd} executeQuery: Code: 241. DB::Exception: Memory tracker (for query): fault injected. Would use 6.03 MiB (attempt to allocate chunk of 1048639 bytes), maximum: 9.31 GiB. (MEMORY_LIMIT_EXCEEDED) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:56490) (comment: 01890_jit_aggregation_function_sum_long.sql) (in query: INSERT INTO test_table_nullable_float_values SELECT number % 3, number, number FROM system.numbers LIMIT 120;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, char const*&&, String&&, long&, String&&) @ 0x000000001adfc3f5 4. ./build_docker/./src/Common/MemoryTracker.cpp:284: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001adfafab 5. ./build_docker/./src/Common/MemoryTracker.cpp:0: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001adfa777 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:59: CurrentMemoryTracker::alloc(long) @ 0x000000001ad3289d 7. ./build_docker/./src/Common/Allocator.cpp:151: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001ad2eb85 8. ./src/IO/BufferWithOwnMemory.h:130: DB::Memory>::alloc(unsigned long) @ 0x000000001aeaaa00 9. ./src/IO/BufferWithOwnMemory.h:80: DB::CompressedWriteBuffer::CompressedWriteBuffer(DB::WriteBuffer&, std::shared_ptr, unsigned long) @ 0x000000002776618f 10. ./build_docker/./src/Storages/StorageLog.cpp:360: DB::LogSink::Stream::Stream(std::shared_ptr const&, String const&, unsigned long, std::shared_ptr, unsigned long) @ 0x000000002be26948 11. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:35: std::pair* std::construct_at[abi:v15007], std::piecewise_construct_t const&, std::tuple, std::tuple const&, String const&, unsigned long&&, std::shared_ptr&, unsigned long const&>, std::pair*>(std::pair*, std::piecewise_construct_t const&, std::tuple&&, std::tuple const&, String const&, unsigned long&&, std::shared_ptr&, unsigned long const&>&&) @ 0x000000002be263e0 12. ./contrib/llvm-project/libcxx/include/__tree:2096: std::pair, std::__tree_node, void*>*, long>, bool> std::__tree, std::__map_value_compare, std::less, true>, std::allocator>>::__emplace_unique_key_args, std::tuple const&, String const&, unsigned long&&, std::shared_ptr&, unsigned long const&>>(String const&, std::piecewise_construct_t const&, std::tuple&&, std::tuple const&, String const&, unsigned long&&, std::shared_ptr&, unsigned long const&>&&) @ 0x000000002be25c0e 13. ./contrib/llvm-project/libcxx/include/map:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x000000002be19b99 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000027a9e455 15. ./build_docker/./src/DataTypes/Serializations/SerializationNullable.cpp:0: DB::SerializationNullable::enumerateStreams(DB::ISerialization::EnumerateStreamsSettings&, std::function const&, DB::ISerialization::SubstreamData const&) const @ 0x0000000027b78cf5 16. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:106: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x0000000027a9ea65 17. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:100: DB::LogSink::writeData(DB::NameAndTypePair const&, DB::IColumn const&) @ 0x000000002be05130 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::LogSink::consume(DB::Chunk&) @ 0x000000002be04a97 19. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:11: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000002dbe182e 20. ./contrib/llvm-project/libcxx/include/vector:432: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000002d9c1a3a 21. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:102: DB::runStep(std::function, DB::ThreadStatus*, std::atomic*) @ 0x000000002d9c1551 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d9c06a6 23. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 25. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000002d34877c 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000002d34827b 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*) @ 0x000000002d3463e7 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 30. asan_thread_start(void*) @ 0x000000000aa43059 31. ? @ 0x00007f35aab92ac3 2025.09.09 15:08:58.795710 [ 20379 ] {ae5f8504-0381-4b25-8a4e-0f892cea2efd} TCPHandler: Code: 241. DB::Exception: Memory tracker (for query): fault injected. Would use 6.03 MiB (attempt to allocate chunk of 1048639 bytes), maximum: 9.31 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, char const*&&, String&&, long&, String&&) @ 0x000000001adfc3f5 4. ./build_docker/./src/Common/MemoryTracker.cpp:284: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001adfafab 5. ./build_docker/./src/Common/MemoryTracker.cpp:0: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001adfa777 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:59: CurrentMemoryTracker::alloc(long) @ 0x000000001ad3289d 7. ./build_docker/./src/Common/Allocator.cpp:151: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001ad2eb85 8. ./src/IO/BufferWithOwnMemory.h:130: DB::Memory>::alloc(unsigned long) @ 0x000000001aeaaa00 9. ./src/IO/BufferWithOwnMemory.h:80: DB::CompressedWriteBuffer::CompressedWriteBuffer(DB::WriteBuffer&, std::shared_ptr, unsigned long) @ 0x000000002776618f 10. ./build_docker/./src/Storages/StorageLog.cpp:360: DB::LogSink::Stream::Stream(std::shared_ptr const&, String const&, unsigned long, std::shared_ptr, unsigned long) @ 0x000000002be26948 11. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:35: std::pair* std::construct_at[abi:v15007], std::piecewise_construct_t const&, std::tuple, std::tuple const&, String const&, unsigned long&&, std::shared_ptr&, unsigned long const&>, std::pair*>(std::pair*, std::piecewise_construct_t const&, std::tuple&&, std::tuple const&, String const&, unsigned long&&, std::shared_ptr&, unsigned long const&>&&) @ 0x000000002be263e0 12. ./contrib/llvm-project/libcxx/include/__tree:2096: std::pair, std::__tree_node, void*>*, long>, bool> std::__tree, std::__map_value_compare, std::less, true>, std::allocator>>::__emplace_unique_key_args, std::tuple const&, String const&, unsigned long&&, std::shared_ptr&, unsigned long const&>>(String const&, std::piecewise_construct_t const&, std::tuple&&, std::tuple const&, String const&, unsigned long&&, std::shared_ptr&, unsigned long const&>&&) @ 0x000000002be25c0e 13. ./contrib/llvm-project/libcxx/include/map:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x000000002be19b99 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000027a9e455 15. ./build_docker/./src/DataTypes/Serializations/SerializationNullable.cpp:0: DB::SerializationNullable::enumerateStreams(DB::ISerialization::EnumerateStreamsSettings&, std::function const&, DB::ISerialization::SubstreamData const&) const @ 0x0000000027b78cf5 16. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:106: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x0000000027a9ea65 17. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:100: DB::LogSink::writeData(DB::NameAndTypePair const&, DB::IColumn const&) @ 0x000000002be05130 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::LogSink::consume(DB::Chunk&) @ 0x000000002be04a97 19. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:11: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000002dbe182e 20. ./contrib/llvm-project/libcxx/include/vector:432: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000002d9c1a3a 21. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:102: DB::runStep(std::function, DB::ThreadStatus*, std::atomic*) @ 0x000000002d9c1551 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d9c06a6 23. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 25. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000002d34877c 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000002d34827b 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*) @ 0x000000002d3463e7 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 30. asan_thread_start(void*) @ 0x000000000aa43059 31. ? @ 0x00007f35aab92ac3 2025.09.09 15:08:59.162771 [ 3079 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:08:59.319677 [ 3087 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:08:59.370067 [ 3104 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:08:59.753272 [ 3113 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:09:00.165608 [ 3188 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:09:00.326254 [ 3184 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:09:00.372911 [ 3185 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:09:00.756238 [ 3211 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:09:01.168714 [ 3243 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:09:01.329230 [ 2757 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:09:01.376045 [ 2756 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:09:01.535816 [ 20345 ] {5616c6cf-f169-4298-a345-70730f0060d9} executeQuery: Code: 42. DB::Exception: Number of arguments for function minSampleSizeContinuous doesn't match: passed 2, should be 5: In scope SELECT minSampleSizeContinous(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT minSampleSizeContinous(NULL, NULL);) 2025.09.09 15:09:01.540258 [ 20345 ] {5616c6cf-f169-4298-a345-70730f0060d9} TCPHandler: Code: 42. DB::Exception: Number of arguments for function minSampleSizeContinuous doesn't match: passed 2, should be 5: In scope SELECT minSampleSizeContinous(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:09:01.594727 [ 20345 ] {ffe3b4d4-d7ba-4cf7-b2f4-c0a089ed05f8} executeQuery: Code: 42. DB::Exception: Number of arguments for function minSampleSizeContinuous doesn't match: passed 2, should be 5: In scope SELECT minSampleSizeContinuous(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT minSampleSizeContinuous(NULL, NULL);) 2025.09.09 15:09:01.599782 [ 20345 ] {ffe3b4d4-d7ba-4cf7-b2f4-c0a089ed05f8} TCPHandler: Code: 42. DB::Exception: Number of arguments for function minSampleSizeContinuous doesn't match: passed 2, should be 5: In scope SELECT minSampleSizeContinuous(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:09:01.670340 [ 20345 ] {de9c1679-44c3-402d-90ff-f8e876eb5e14} executeQuery: Code: 42. DB::Exception: Number of arguments for function minSampleSizeConversion doesn't match: passed 2, should be 4: In scope SELECT minSampleSizeConversion(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT minSampleSizeConversion(NULL, NULL);) 2025.09.09 15:09:01.675582 [ 20345 ] {de9c1679-44c3-402d-90ff-f8e876eb5e14} TCPHandler: Code: 42. DB::Exception: Number of arguments for function minSampleSizeConversion doesn't match: passed 2, should be 4: In scope SELECT minSampleSizeConversion(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:09:01.759277 [ 2759 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:09:02.171689 [ 2787 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:09:02.332202 [ 2770 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:09:02.382347 [ 3058 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:09:02.538356 [ 20345 ] {08f1844c-0722-40a2-9aa8-30852b05b464} executeQuery: Code: 42. DB::Exception: Number of arguments for function monthName doesn't match: passed 2, should be 1: In scope SELECT monthName(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT monthName(NULL, NULL);) 2025.09.09 15:09:02.553116 [ 20345 ] {08f1844c-0722-40a2-9aa8-30852b05b464} TCPHandler: Code: 42. DB::Exception: Number of arguments for function monthName doesn't match: passed 2, should be 1: In scope SELECT monthName(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:09:02.762496 [ 2831 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:09:02.907903 [ 20345 ] {df03ee08-1faa-4b7d-bab8-6e6cfaf63188} executeQuery: Code: 42. DB::Exception: Number of arguments for function multiFuzzyMatchAllIndices doesn't match: passed 2, should be 3: In scope SELECT multiFuzzyMatchAllIndices(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT multiFuzzyMatchAllIndices(NULL, NULL);) 2025.09.09 15:09:02.916028 [ 20345 ] {df03ee08-1faa-4b7d-bab8-6e6cfaf63188} TCPHandler: Code: 42. DB::Exception: Number of arguments for function multiFuzzyMatchAllIndices doesn't match: passed 2, should be 3: In scope SELECT multiFuzzyMatchAllIndices(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:09:03.064677 [ 20345 ] {f7abb6d7-a175-4979-bd14-757e487ddfac} executeQuery: Code: 42. DB::Exception: Number of arguments for function multiFuzzyMatchAny doesn't match: passed 2, should be 3: In scope SELECT multiFuzzyMatchAny(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT multiFuzzyMatchAny(NULL, NULL);) 2025.09.09 15:09:03.069283 [ 20345 ] {f7abb6d7-a175-4979-bd14-757e487ddfac} TCPHandler: Code: 42. DB::Exception: Number of arguments for function multiFuzzyMatchAny doesn't match: passed 2, should be 3: In scope SELECT multiFuzzyMatchAny(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:09:03.116667 [ 20345 ] {87f9c01c-1383-45d7-ae32-637aabb19146} executeQuery: Code: 42. DB::Exception: Number of arguments for function multiFuzzyMatchAnyIndex doesn't match: passed 2, should be 3: In scope SELECT multiFuzzyMatchAnyIndex(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT multiFuzzyMatchAnyIndex(NULL, NULL);) 2025.09.09 15:09:03.121529 [ 20345 ] {87f9c01c-1383-45d7-ae32-637aabb19146} TCPHandler: Code: 42. DB::Exception: Number of arguments for function multiFuzzyMatchAnyIndex doesn't match: passed 2, should be 3: In scope SELECT multiFuzzyMatchAnyIndex(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:09:03.174564 [ 2901 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:09:03.189149 [ 20345 ] {a7e5615b-1ff1-42bb-9858-e9310aca2a5e} executeQuery: Code: 42. DB::Exception: Invalid number of arguments for function multiIf: In scope SELECT multiIf(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT multiIf(NULL, NULL);) 2025.09.09 15:09:03.196299 [ 20345 ] {a7e5615b-1ff1-42bb-9858-e9310aca2a5e} TCPHandler: Code: 42. DB::Exception: Invalid number of arguments for function multiIf: In scope SELECT multiIf(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:09:03.335464 [ 2891 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:09:03.425735 [ 2866 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:09:03.774224 [ 2873 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:09:04.187242 [ 2970 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:09:04.342942 [ 2986 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:09:04.428250 [ 2959 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:09:04.777961 [ 2962 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:09:05.047415 [ 3722 ] {81880b92-a0ac-48b9-a7db-058ffc21fa90} executeQuery: Code: 70. DB::Exception: Cannot convert infinite value to integer type. (CANNOT_CONVERT_TYPE) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:49170) (comment: 01557_field_infinite_convert_to_number.sql) (in query: SET max_threads = nan;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aac868e 4. ./build_docker/./src/Core/SettingsFields.cpp:88: unsigned long DB::(anonymous namespace)::fieldToNumber(DB::Field const&) @ 0x0000000027740885 5. ./build_docker/./src/Core/SettingsFields.cpp:223: DB::SettingFieldMaxThreads::SettingFieldMaxThreads(DB::Field const&) @ 0x0000000027744f3b 6. ./src/Core/Field.h:707: DB::SettingsTraits::Accessor::instance()::$_0::operator()() const::'lambda31'(DB::Field const&)::__invoke(DB::Field const&) @ 0x000000002737f017 7. ./src/Core/Settings.h:1318: bool DB::getNewValueToCheck(DB::Settings const&, DB::SettingChange&, DB::Field&, bool) @ 0x0000000026f83291 8. ./build_docker/./src/Access/SettingsConstraints.cpp:285: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f80276 9. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x0000000026f807e3 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x000000002853b6ad 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterSetQuery::execute() @ 0x00000000294f603b 12. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b382fc 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 15. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 19. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 20. asan_thread_start(void*) @ 0x000000000aa43059 21. ? @ 0x00007f35aab92ac3 22. ? @ 0x00007f35aac24850 2025.09.09 15:09:05.058053 [ 3722 ] {81880b92-a0ac-48b9-a7db-058ffc21fa90} TCPHandler: Code: 70. DB::Exception: Cannot convert infinite value to integer type. (CANNOT_CONVERT_TYPE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aac868e 4. ./build_docker/./src/Core/SettingsFields.cpp:88: unsigned long DB::(anonymous namespace)::fieldToNumber(DB::Field const&) @ 0x0000000027740885 5. ./build_docker/./src/Core/SettingsFields.cpp:223: DB::SettingFieldMaxThreads::SettingFieldMaxThreads(DB::Field const&) @ 0x0000000027744f3b 6. ./src/Core/Field.h:707: DB::SettingsTraits::Accessor::instance()::$_0::operator()() const::'lambda31'(DB::Field const&)::__invoke(DB::Field const&) @ 0x000000002737f017 7. ./src/Core/Settings.h:1318: bool DB::getNewValueToCheck(DB::Settings const&, DB::SettingChange&, DB::Field&, bool) @ 0x0000000026f83291 8. ./build_docker/./src/Access/SettingsConstraints.cpp:285: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f80276 9. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x0000000026f807e3 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x000000002853b6ad 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterSetQuery::execute() @ 0x00000000294f603b 12. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b382fc 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 15. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 19. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 20. asan_thread_start(void*) @ 0x000000000aa43059 21. ? @ 0x00007f35aab92ac3 22. ? @ 0x00007f35aac24850 2025.09.09 15:09:05.192864 [ 2996 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:09:05.345496 [ 3056 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:09:05.439705 [ 3057 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:09:05.585746 [ 20379 ] {1998819a-4845-429b-9ef7-421c084db79c} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=2, jobs=2). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:49148) (comment: 03166_skip_indexes_vertical_merge_2.sql) (in query: --- merged: a, c, d; gathered: b, e, f WITH (SELECT uuid FROM system.tables WHERE database = currentDatabase() AND table = 't_ind_merge_2') AS uuid, extractAllGroupsVertical(message, 'containing (\\d+) columns \((\\d+) merged, (\\d+) gathered\)')[1] AS groups SELECT groups[1] AS total, groups[2] AS merged, groups[3] AS gathered FROM system.text_log WHERE ((query_id = uuid || '::all_1_2_1') OR (query_id = currentDatabase() || '.t_ind_merge_2::all_1_2_1')) AND notEmpty(groups) 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af80b71 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80746 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d34b5ca 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000002d3486e4 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000002d34827b 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002d36bcf7 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 12. asan_thread_start(void*) @ 0x000000000aa43059 13. ? @ 0x00007f35aab92ac3 14. ? @ 0x00007f35aac24850 2025.09.09 15:09:05.592027 [ 20379 ] {1998819a-4845-429b-9ef7-421c084db79c} 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af80b71 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80746 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d34b5ca 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000002d3486e4 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000002d34827b 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002d36bcf7 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 12. asan_thread_start(void*) @ 0x000000000aa43059 13. ? @ 0x00007f35aab92ac3 14. ? @ 0x00007f35aac24850 2025.09.09 15:09:05.785127 [ 3041 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:09:06.195100 [ 3083 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:09:06.355308 [ 3124 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:09:06.445592 [ 3132 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:09:06.684636 [ 20345 ] {94d03c46-ebba-45ae-9d8f-2299788dcfd8} executeQuery: Code: 42. DB::Exception: Number of arguments for function negate doesn't match: passed 2, should be 1: In scope SELECT negate(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT negate(NULL, NULL);) 2025.09.09 15:09:06.690716 [ 20345 ] {94d03c46-ebba-45ae-9d8f-2299788dcfd8} TCPHandler: Code: 42. DB::Exception: Number of arguments for function negate doesn't match: passed 2, should be 1: In scope SELECT negate(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:09:06.759297 [ 20345 ] {11d0ebf0-f2d8-4b73-89a4-9ba9660fef0e} executeQuery: Code: 721. DB::Exception: Function neighbor is deprecated since its usage is error-prone (see docs).Please use proper window function or set `allow_deprecated_error_prone_window_functions` setting to enable it. (DEPRECATED_FUNCTION) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT neighbor(NULL, NULL);) 2025.09.09 15:09:06.766554 [ 20345 ] {11d0ebf0-f2d8-4b73-89a4-9ba9660fef0e} TCPHandler: Code: 721. DB::Exception: Function neighbor is deprecated since its usage is error-prone (see docs).Please use proper window function or set `allow_deprecated_error_prone_window_functions` setting to enable it. (DEPRECATED_FUNCTION) 2025.09.09 15:09:06.788354 [ 3125 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:09:06.929335 [ 20345 ] {eeb84d97-1597-4b36-ac21-a08b3b8453bb} executeQuery: Code: 42. DB::Exception: Number of arguments for function netloc doesn't match: passed 2, should be 1: In scope SELECT netloc(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT netloc(NULL, NULL);) 2025.09.09 15:09:06.934540 [ 20345 ] {eeb84d97-1597-4b36-ac21-a08b3b8453bb} TCPHandler: Code: 42. DB::Exception: Number of arguments for function netloc doesn't match: passed 2, should be 1: In scope SELECT netloc(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:09:07.198311 [ 3182 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:09:07.357330 [ 3214 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:09:07.449057 [ 3196 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:09:07.854125 [ 3243 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:09:08.081568 [ 3722 ] {d2d194c5-96c0-463d-85b2-7eea422efe52} executeQuery: Code: 407. DB::Exception: Numeric overflow: while executing 'FUNCTION plus(toDateTime(toStartOfFifteenMinutes(plus(_CAST(1000_DateTime, 'DateTime'_String), multiply(__table2.number, 65536_UInt32)))) :: 3, multiply(__table2.number, 9223372036854775807_UInt64) :: 2) -> plus(toDateTime(toStartOfFifteenMinutes(plus(_CAST(1000_DateTime, 'DateTime'_String), multiply(__table2.number, 65536_UInt32)))), multiply(__table2.number, 9223372036854775807_UInt64)) DateTime : 0'. (DECIMAL_OVERFLOW) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:49186) (comment: 02772_jit_date_time_add.sql) (in query: SELECT DISTINCT result FROM (SELECT toStartOfFifteenMinutes(toDateTime(toStartOfFifteenMinutes(toDateTime(1000.0001220703125) + (number * 65536))) + (number * 9223372036854775807)) AS result FROM system.numbers LIMIT 1048576) ORDER BY result DESC NULLS FIRST FORMAT Null;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aac868e 4. void DB::Processor::vectorVector, DB::ColumnVector, DB::ColumnVector>(DB::ColumnVector const&, DB::ColumnVector&, DB::ColumnVector const&, DateLUTImpl const&, unsigned short, unsigned long) const @ 0x000000000cee308f 5. void DB::Processor::vectorVector, DB::ColumnVector>(DB::ColumnVector const&, DB::ColumnVector&, DB::IColumn const&, DateLUTImpl const&, unsigned short, unsigned long) const @ 0x000000000cee06b6 6. DB::DateTimeAddIntervalImpl::execute(DB::AddSecondsImpl, std::vector> const&, std::shared_ptr const&, unsigned short, unsigned long) @ 0x000000000cecf7ae 7. DB::FunctionDateOrDateTimeAddInterval::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000cecc3a7 8. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aac9135 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000cccce5b 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccce65c 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd2030 12. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000aac7d8f 13. DB::FunctionBinaryArithmetic::executeDateTimeIntervalPlusMinus(std::vector> const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&) const @ 0x0000000016eac11f 14. DB::FunctionBinaryArithmetic::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000016eaa360 15. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aac9135 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000cccce5b 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccce65c 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd2030 19. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x00000000286fc2bd 20. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000002d9c29ae 21. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 22. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 23. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 25. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000002d34877c 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000002d34827b 27. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002d36bcf7 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 30. asan_thread_start(void*) @ 0x000000000aa43059 31. ? @ 0x00007f35aab92ac3 2025.09.09 15:09:08.084661 [ 3722 ] {d2d194c5-96c0-463d-85b2-7eea422efe52} TCPHandler: Code: 407. DB::Exception: Numeric overflow: while executing 'FUNCTION plus(toDateTime(toStartOfFifteenMinutes(plus(_CAST(1000_DateTime, 'DateTime'_String), multiply(__table2.number, 65536_UInt32)))) :: 3, multiply(__table2.number, 9223372036854775807_UInt64) :: 2) -> plus(toDateTime(toStartOfFifteenMinutes(plus(_CAST(1000_DateTime, 'DateTime'_String), multiply(__table2.number, 65536_UInt32)))), multiply(__table2.number, 9223372036854775807_UInt64)) DateTime : 0'. (DECIMAL_OVERFLOW), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aac868e 4. void DB::Processor::vectorVector, DB::ColumnVector, DB::ColumnVector>(DB::ColumnVector const&, DB::ColumnVector&, DB::ColumnVector const&, DateLUTImpl const&, unsigned short, unsigned long) const @ 0x000000000cee308f 5. void DB::Processor::vectorVector, DB::ColumnVector>(DB::ColumnVector const&, DB::ColumnVector&, DB::IColumn const&, DateLUTImpl const&, unsigned short, unsigned long) const @ 0x000000000cee06b6 6. DB::DateTimeAddIntervalImpl::execute(DB::AddSecondsImpl, std::vector> const&, std::shared_ptr const&, unsigned short, unsigned long) @ 0x000000000cecf7ae 7. DB::FunctionDateOrDateTimeAddInterval::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000cecc3a7 8. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aac9135 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000cccce5b 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccce65c 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd2030 12. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000aac7d8f 13. DB::FunctionBinaryArithmetic::executeDateTimeIntervalPlusMinus(std::vector> const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&) const @ 0x0000000016eac11f 14. DB::FunctionBinaryArithmetic::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000016eaa360 15. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aac9135 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000cccce5b 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccce65c 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd2030 19. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x00000000286fc2bd 20. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000002d9c29ae 21. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49a31f 22. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d323859 23. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 25. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000002d34877c 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000002d34827b 27. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002d36bcf7 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 30. asan_thread_start(void*) @ 0x000000000aa43059 31. ? @ 0x00007f35aab92ac3 2025.09.09 15:09:08.201958 [ 3207 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:09:08.360200 [ 2782 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:09:08.452003 [ 3235 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:09:08.857371 [ 2788 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:09:09.205232 [ 2824 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:09:09.363469 [ 2843 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:09:09.454647 [ 2846 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:09:09.859454 [ 2928 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:09:10.208810 [ 2887 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:09:10.298090 [ 20345 ] {9069bcaa-fdfe-41a5-b28a-4245d4bc0013} executeQuery: Code: 36. DB::Exception: Argument 0 must be a number, 'Nullable(Nothing)' given. (BAD_ARGUMENTS) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT nonNegativeDerivative(NULL, NULL);) 2025.09.09 15:09:10.306487 [ 20345 ] {9069bcaa-fdfe-41a5-b28a-4245d4bc0013} TCPHandler: Code: 36. DB::Exception: Argument 0 must be a number, 'Nullable(Nothing)' given. (BAD_ARGUMENTS) 2025.09.09 15:09:10.374342 [ 2919 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:09:10.457191 [ 20345 ] {dba46fc0-3e92-4b50-bc7e-9ecdac93cefa} executeQuery: Code: 42. DB::Exception: Number of arguments for function L1Norm doesn't match: passed 2, should be 1: In scope SELECT normL1(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT normL1(NULL, NULL);) 2025.09.09 15:09:10.457817 [ 2933 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:09:10.462264 [ 20345 ] {dba46fc0-3e92-4b50-bc7e-9ecdac93cefa} TCPHandler: Code: 42. DB::Exception: Number of arguments for function L1Norm doesn't match: passed 2, should be 1: In scope SELECT normL1(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:09:10.622342 [ 20345 ] {191320d4-5cea-4913-a05a-23736c46842b} executeQuery: Code: 42. DB::Exception: Number of arguments for function L2Norm doesn't match: passed 2, should be 1: In scope SELECT normL2(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT normL2(NULL, NULL);) 2025.09.09 15:09:10.625570 [ 20345 ] {191320d4-5cea-4913-a05a-23736c46842b} TCPHandler: Code: 42. DB::Exception: Number of arguments for function L2Norm doesn't match: passed 2, should be 1: In scope SELECT normL2(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:09:10.684544 [ 20345 ] {50331d7d-d52c-4591-8c22-5efacec5fc04} executeQuery: Code: 42. DB::Exception: Number of arguments for function L2SquaredNorm doesn't match: passed 2, should be 1: In scope SELECT normL2Squared(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT normL2Squared(NULL, NULL);) 2025.09.09 15:09:10.688508 [ 20345 ] {50331d7d-d52c-4591-8c22-5efacec5fc04} TCPHandler: Code: 42. DB::Exception: Number of arguments for function L2SquaredNorm doesn't match: passed 2, should be 1: In scope SELECT normL2Squared(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:09:10.745343 [ 20345 ] {59ffb4a2-401f-4600-b49e-2860f9011f21} executeQuery: Code: 42. DB::Exception: Number of arguments for function LinfNorm doesn't match: passed 2, should be 1: In scope SELECT normLinf(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT normLinf(NULL, NULL);) 2025.09.09 15:09:10.750135 [ 20345 ] {59ffb4a2-401f-4600-b49e-2860f9011f21} TCPHandler: Code: 42. DB::Exception: Number of arguments for function LinfNorm doesn't match: passed 2, should be 1: In scope SELECT normLinf(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:09:10.861063 [ 2979 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:09:10.869876 [ 20345 ] {a74de2e1-8f61-4c5c-aaf1-b1458266d8f0} executeQuery: Code: 42. DB::Exception: Number of arguments for function L1Normalize doesn't match: passed 2, should be 1: In scope SELECT normalizeL1(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT normalizeL1(NULL, NULL);) 2025.09.09 15:09:10.883580 [ 20345 ] {a74de2e1-8f61-4c5c-aaf1-b1458266d8f0} TCPHandler: Code: 42. DB::Exception: Number of arguments for function L1Normalize doesn't match: passed 2, should be 1: In scope SELECT normalizeL1(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:09:10.995535 [ 20345 ] {ace4713a-6503-46d8-ba69-ce1c4d7e3b74} executeQuery: Code: 42. DB::Exception: Number of arguments for function L2Normalize doesn't match: passed 2, should be 1: In scope SELECT normalizeL2(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT normalizeL2(NULL, NULL);) 2025.09.09 15:09:11.003702 [ 20345 ] {ace4713a-6503-46d8-ba69-ce1c4d7e3b74} TCPHandler: Code: 42. DB::Exception: Number of arguments for function L2Normalize doesn't match: passed 2, should be 1: In scope SELECT normalizeL2(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:09:11.064622 [ 20345 ] {0cdfec22-9cde-454d-b7aa-bae0a8e145a0} executeQuery: Code: 42. DB::Exception: Number of arguments for function LinfNormalize doesn't match: passed 2, should be 1: In scope SELECT normalizeLinf(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT normalizeLinf(NULL, NULL);) 2025.09.09 15:09:11.073882 [ 20345 ] {0cdfec22-9cde-454d-b7aa-bae0a8e145a0} TCPHandler: Code: 42. DB::Exception: Number of arguments for function LinfNormalize doesn't match: passed 2, should be 1: In scope SELECT normalizeLinf(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:09:11.159560 [ 3722 ] {} 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 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) @ 0x000000002964ee6e 5. ./build_docker/./src/Interpreters/Session.cpp:571: DB::Session::makeSessionContext(String const&, std::chrono::duration>, bool) @ 0x0000000029649d02 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000002d060f19 7. ./build_docker/./src/Server/HTTPHandler.cpp:705: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000002d06d139 8. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000002d1cc337 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 12. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 13. asan_thread_start(void*) @ 0x000000000aa43059 14. ? @ 0x00007f35aab92ac3 15. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:09:11.211971 [ 2981 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:09:11.289034 [ 20345 ] {5a1fcaff-aa96-433c-88f8-a129b9882cb5} executeQuery: Code: 42. DB::Exception: Number of arguments for function normalizeQuery doesn't match: passed 2, should be 1: In scope SELECT normalizeQuery(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT normalizeQuery(NULL, NULL);) 2025.09.09 15:09:11.294910 [ 20345 ] {5a1fcaff-aa96-433c-88f8-a129b9882cb5} TCPHandler: Code: 42. DB::Exception: Number of arguments for function normalizeQuery doesn't match: passed 2, should be 1: In scope SELECT normalizeQuery(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:09:11.376728 [ 2998 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:09:11.455515 [ 20345 ] {6e365d59-24bc-4362-a4da-f1adce7b506f} executeQuery: Code: 42. DB::Exception: Number of arguments for function normalizeQueryKeepNames doesn't match: passed 2, should be 1: In scope SELECT normalizeQueryKeepNames(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT normalizeQueryKeepNames(NULL, NULL);) 2025.09.09 15:09:11.460330 [ 2982 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:09:11.461359 [ 20345 ] {6e365d59-24bc-4362-a4da-f1adce7b506f} TCPHandler: Code: 42. DB::Exception: Number of arguments for function normalizeQueryKeepNames doesn't match: passed 2, should be 1: In scope SELECT normalizeQueryKeepNames(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:09:11.531535 [ 20345 ] {3bdd10c8-f26f-4d09-9e72-50613afe5ff6} executeQuery: Code: 42. DB::Exception: Number of arguments for function normalizeUTF8NFC doesn't match: passed 2, should be 1: In scope SELECT normalizeUTF8NFC(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT normalizeUTF8NFC(NULL, NULL);) 2025.09.09 15:09:11.535328 [ 20345 ] {3bdd10c8-f26f-4d09-9e72-50613afe5ff6} TCPHandler: Code: 42. DB::Exception: Number of arguments for function normalizeUTF8NFC doesn't match: passed 2, should be 1: In scope SELECT normalizeUTF8NFC(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:09:11.573306 [ 20345 ] {662bbdf7-72a8-4065-b85a-03f7dd93011f} executeQuery: Code: 42. DB::Exception: Number of arguments for function normalizeUTF8NFD doesn't match: passed 2, should be 1: In scope SELECT normalizeUTF8NFD(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT normalizeUTF8NFD(NULL, NULL);) 2025.09.09 15:09:11.576260 [ 20345 ] {662bbdf7-72a8-4065-b85a-03f7dd93011f} TCPHandler: Code: 42. DB::Exception: Number of arguments for function normalizeUTF8NFD doesn't match: passed 2, should be 1: In scope SELECT normalizeUTF8NFD(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:09:11.652544 [ 20345 ] {d30a8ffd-a5c8-4878-9db5-022f872f40fb} executeQuery: Code: 42. DB::Exception: Number of arguments for function normalizeUTF8NFKC doesn't match: passed 2, should be 1: In scope SELECT normalizeUTF8NFKC(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT normalizeUTF8NFKC(NULL, NULL);) 2025.09.09 15:09:11.660588 [ 20345 ] {d30a8ffd-a5c8-4878-9db5-022f872f40fb} TCPHandler: Code: 42. DB::Exception: Number of arguments for function normalizeUTF8NFKC doesn't match: passed 2, should be 1: In scope SELECT normalizeUTF8NFKC(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:09:11.739811 [ 20345 ] {793f27bb-9c0e-4932-86d2-b296f4e95a07} executeQuery: Code: 42. DB::Exception: Number of arguments for function normalizeUTF8NFKD doesn't match: passed 2, should be 1: In scope SELECT normalizeUTF8NFKD(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT normalizeUTF8NFKD(NULL, NULL);) 2025.09.09 15:09:11.744471 [ 20345 ] {793f27bb-9c0e-4932-86d2-b296f4e95a07} TCPHandler: Code: 42. DB::Exception: Number of arguments for function normalizeUTF8NFKD doesn't match: passed 2, should be 1: In scope SELECT normalizeUTF8NFKD(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:09:11.826301 [ 20345 ] {c239e635-953b-49cf-89bd-62958c74bc86} executeQuery: Code: 42. DB::Exception: Number of arguments for function normalizedQueryHash doesn't match: passed 2, should be 1: In scope SELECT normalizedQueryHash(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT normalizedQueryHash(NULL, NULL);) 2025.09.09 15:09:11.856721 [ 20345 ] {c239e635-953b-49cf-89bd-62958c74bc86} TCPHandler: Code: 42. DB::Exception: Number of arguments for function normalizedQueryHash doesn't match: passed 2, should be 1: In scope SELECT normalizedQueryHash(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:09:11.863717 [ 3078 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:09:12.057819 [ 20345 ] {836961c6-3d02-4c87-968c-ef69af9d70e0} executeQuery: Code: 42. DB::Exception: Number of arguments for function normalizedQueryHashKeepNames doesn't match: passed 2, should be 1: In scope SELECT normalizedQueryHashKeepNames(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT normalizedQueryHashKeepNames(NULL, NULL);) 2025.09.09 15:09:12.066860 [ 20345 ] {836961c6-3d02-4c87-968c-ef69af9d70e0} TCPHandler: Code: 42. DB::Exception: Number of arguments for function normalizedQueryHashKeepNames doesn't match: passed 2, should be 1: In scope SELECT normalizedQueryHashKeepNames(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:09:12.215245 [ 3022 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:09:12.283221 [ 20345 ] {cb33b212-bca0-4180-bb83-b50c458e3800} executeQuery: Code: 42. DB::Exception: Number of arguments for function not doesn't match: passed 2, should be 1: In scope SELECT not(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT not(NULL, NULL);) 2025.09.09 15:09:12.291569 [ 20345 ] {cb33b212-bca0-4180-bb83-b50c458e3800} TCPHandler: Code: 42. DB::Exception: Number of arguments for function not doesn't match: passed 2, should be 1: In scope SELECT not(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:09:12.379738 [ 3076 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:09:12.392018 [ 20345 ] {d911b218-f755-4c66-b279-1806e7a20a11} executeQuery: Code: 42. DB::Exception: Number of arguments for function notEmpty doesn't match: passed 2, should be 1: In scope SELECT notEmpty(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT notEmpty(NULL, NULL);) 2025.09.09 15:09:12.399227 [ 20345 ] {d911b218-f755-4c66-b279-1806e7a20a11} TCPHandler: Code: 42. DB::Exception: Number of arguments for function notEmpty doesn't match: passed 2, should be 1: In scope SELECT notEmpty(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:09:12.463333 [ 3067 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:09:12.867610 [ 3114 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:09:13.218108 [ 3143 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:09:13.382113 [ 3137 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:09:13.465453 [ 3172 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:09:13.869859 [ 3203 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:09:14.206558 [ 20345 ] {425716e8-9918-4b08-aea8-8211ed90b2d8} executeQuery: Code: 42. DB::Exception: Arguments size of function now should be 0 or 1: In scope SELECT now(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT now(NULL, NULL);) 2025.09.09 15:09:14.212675 [ 20345 ] {425716e8-9918-4b08-aea8-8211ed90b2d8} TCPHandler: Code: 42. DB::Exception: Arguments size of function now should be 0 or 1: In scope SELECT now(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:09:14.220594 [ 3243 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:09:14.384318 [ 2765 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:09:14.467424 [ 3169 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:09:14.531414 [ 20345 ] {9136d066-b041-4cc4-a1e4-8875ce2de7e0} executeQuery: Code: 36. DB::Exception: Offset must be an integer, 'Nullable(Nothing)' given. (BAD_ARGUMENTS) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT nth_value(NULL, NULL);) 2025.09.09 15:09:14.542302 [ 20345 ] {9136d066-b041-4cc4-a1e4-8875ce2de7e0} TCPHandler: Code: 36. DB::Exception: Offset must be an integer, 'Nullable(Nothing)' given. (BAD_ARGUMENTS) 2025.09.09 15:09:14.652099 [ 20345 ] {3e263600-0972-4937-9b17-0c8ef7ce6c57} executeQuery: Code: 42. DB::Exception: Function ntile takes exactly one argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT ntile(NULL, NULL);) 2025.09.09 15:09:14.655367 [ 20345 ] {3e263600-0972-4937-9b17-0c8ef7ce6c57} TCPHandler: Code: 42. DB::Exception: Function ntile takes exactly one argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:09:14.872643 [ 2755 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:09:15.223791 [ 2797 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:09:15.386895 [ 2804 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:09:15.469429 [ 2819 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:09:15.874763 [ 2878 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:09:16.225868 [ 2923 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:09:16.388678 [ 2953 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:09:16.471307 [ 2914 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:09:16.913858 [ 2979 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:09:17.228545 [ 2992 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:09:17.391773 [ 3008 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:09:17.474827 [ 3006 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:09:17.915753 [ 3028 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:09:18.055196 [ 20345 ] {0fb955fb-3b70-407f-9533-7d9186051075} executeQuery: Code: 42. DB::Exception: Number of arguments for function parseReadableSize doesn't match: passed 2, should be 1: In scope SELECT parseReadableSize(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT parseReadableSize(NULL, NULL);) 2025.09.09 15:09:18.059570 [ 20345 ] {0fb955fb-3b70-407f-9533-7d9186051075} TCPHandler: Code: 42. DB::Exception: Number of arguments for function parseReadableSize doesn't match: passed 2, should be 1: In scope SELECT parseReadableSize(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:09:18.119649 [ 3336 ] {e7207f00-aa15-4cd2-be86-fb903b5c9efa::all_1_1_0_3} MutatePlainMergeTreeTask: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=6, jobs=6). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:09:18.122665 [ 20345 ] {43d52894-34ff-4926-9f28-8f477e84bfab} executeQuery: Code: 42. DB::Exception: Number of arguments for function parseReadableSizeOrNull doesn't match: passed 2, should be 1: In scope SELECT parseReadableSizeOrNull(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT parseReadableSizeOrNull(NULL, NULL);) 2025.09.09 15:09:18.123560 [ 3336 ] {e7207f00-aa15-4cd2-be86-fb903b5c9efa::all_1_1_0_3} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=6, jobs=6). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af80b71 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80746 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d34b5ca 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000002d3486e4 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000002d34827b 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002d36bcf7 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 12. asan_thread_start(void*) @ 0x000000000aa43059 13. ? @ 0x00007f35aab92ac3 14. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:09:18.138467 [ 20345 ] {43d52894-34ff-4926-9f28-8f477e84bfab} TCPHandler: Code: 42. DB::Exception: Number of arguments for function parseReadableSizeOrNull doesn't match: passed 2, should be 1: In scope SELECT parseReadableSizeOrNull(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:09:18.156125 [ 3722 ] {2538d906-a6e4-420e-b1db-cad3ecf98e73} executeQuery: Code: 341. DB::Exception: Exception happened during execution of mutation 'mutation_3.txt' with part 'all_1_1_0_2' reason: 'Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=6, jobs=6). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.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.10505.altinitytest (altinity build)) (from [::1]:43348) (comment: 00699_materialized_view_mutations.sh) (in query: ALTER TABLE view_00699 DELETE WHERE x % 2 = 1;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&&, String&, String&) @ 0x000000002c76d4c6 4. ./build_docker/./src/Storages/MergeTree/MergeTreeMutationStatus.cpp:26: DB::checkMutationStatus(std::optional&, std::set, std::allocator> const&) @ 0x000000002c76d210 5. ./build_docker/./src/Storages/StorageMergeTree.cpp:0: DB::StorageMergeTree::waitForMutation(long, String const&, bool) @ 0x000000002cbbc805 6. ./contrib/llvm-project/libcxx/include/string:1499: DB::StorageMergeTree::mutate(DB::MutationCommands const&, std::shared_ptr) @ 0x000000002cbbe409 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::StorageMaterializedView::mutate(DB::MutationCommands const&, std::shared_ptr) @ 0x000000002b93bc71 8. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000029174a1c 9. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x0000000029170711 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b382fc 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 13. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 18. asan_thread_start(void*) @ 0x000000000aa43059 19. ? @ 0x00007f35aab92ac3 20. ? @ 0x00007f35aac24850 2025.09.09 15:09:18.164474 [ 3722 ] {2538d906-a6e4-420e-b1db-cad3ecf98e73} TCPHandler: Code: 341. DB::Exception: Exception happened during execution of mutation 'mutation_3.txt' with part 'all_1_1_0_2' reason: 'Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=6, jobs=6). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&&, String&, String&) @ 0x000000002c76d4c6 4. ./build_docker/./src/Storages/MergeTree/MergeTreeMutationStatus.cpp:26: DB::checkMutationStatus(std::optional&, std::set, std::allocator> const&) @ 0x000000002c76d210 5. ./build_docker/./src/Storages/StorageMergeTree.cpp:0: DB::StorageMergeTree::waitForMutation(long, String const&, bool) @ 0x000000002cbbc805 6. ./contrib/llvm-project/libcxx/include/string:1499: DB::StorageMergeTree::mutate(DB::MutationCommands const&, std::shared_ptr) @ 0x000000002cbbe409 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::StorageMaterializedView::mutate(DB::MutationCommands const&, std::shared_ptr) @ 0x000000002b93bc71 8. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000029174a1c 9. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x0000000029170711 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b382fc 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 13. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 18. asan_thread_start(void*) @ 0x000000000aa43059 19. ? @ 0x00007f35aab92ac3 20. ? @ 0x00007f35aac24850 2025.09.09 15:09:18.194099 [ 20345 ] {2911514d-bf2f-4833-9586-a9a993de68fc} executeQuery: Code: 42. DB::Exception: Number of arguments for function parseReadableSizeOrZero doesn't match: passed 2, should be 1: In scope SELECT parseReadableSizeOrZero(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT parseReadableSizeOrZero(NULL, NULL);) 2025.09.09 15:09:18.209223 [ 20345 ] {2911514d-bf2f-4833-9586-a9a993de68fc} TCPHandler: Code: 42. DB::Exception: Number of arguments for function parseReadableSizeOrZero doesn't match: passed 2, should be 1: In scope SELECT parseReadableSizeOrZero(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:09:18.231542 [ 3041 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:09:18.394165 [ 3083 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:09:18.476839 [ 3111 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:09:18.637723 [ 20345 ] {35a0600e-959f-4a93-95ca-ec5eb663d07a} executeQuery: Code: 42. DB::Exception: Number of arguments for function path doesn't match: passed 2, should be 1: In scope SELECT path(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT path(NULL, NULL);) 2025.09.09 15:09:18.644774 [ 20345 ] {35a0600e-959f-4a93-95ca-ec5eb663d07a} TCPHandler: Code: 42. DB::Exception: Number of arguments for function path doesn't match: passed 2, should be 1: In scope SELECT path(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:09:18.771174 [ 20345 ] {e52e6fef-a4c6-4bf4-a799-bd2ba438aca2} executeQuery: Code: 42. DB::Exception: Number of arguments for function pathFull doesn't match: passed 2, should be 1: In scope SELECT pathFull(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT pathFull(NULL, NULL);) 2025.09.09 15:09:18.778380 [ 20345 ] {e52e6fef-a4c6-4bf4-a799-bd2ba438aca2} TCPHandler: Code: 42. DB::Exception: Number of arguments for function pathFull doesn't match: passed 2, should be 1: In scope SELECT pathFull(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:09:18.918835 [ 3120 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:09:18.994312 [ 20345 ] {4befeed8-47b3-42cb-91ba-15dd91917ec8} executeQuery: Code: 36. DB::Exception: The function 'percentRank' can only be used as a window function, not as an aggregate function: While executing AggregatingTransform. (BAD_ARGUMENTS) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT percentRank(NULL, NULL);) 2025.09.09 15:09:19.000743 [ 20345 ] {4befeed8-47b3-42cb-91ba-15dd91917ec8} TCPHandler: Code: 36. DB::Exception: The function 'percentRank' can only be used as a window function, not as an aggregate function: While executing AggregatingTransform. (BAD_ARGUMENTS) 2025.09.09 15:09:19.127452 [ 20345 ] {06dfc81c-4ad9-4b8b-8cc9-8fc63a5df0bc} executeQuery: Code: 36. DB::Exception: The function 'percentRank' can only be used as a window function, not as an aggregate function: While executing AggregatingTransform. (BAD_ARGUMENTS) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT percent_rank(NULL, NULL);) 2025.09.09 15:09:19.131942 [ 20345 ] {06dfc81c-4ad9-4b8b-8cc9-8fc63a5df0bc} TCPHandler: Code: 36. DB::Exception: The function 'percentRank' can only be used as a window function, not as an aggregate function: While executing AggregatingTransform. (BAD_ARGUMENTS) 2025.09.09 15:09:19.233772 [ 3191 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:09:19.348136 [ 20345 ] {e6dd0ca0-c01a-4f46-a8e5-4d08d022a8f8} executeQuery: Code: 42. DB::Exception: Number of arguments for function pi doesn't match: passed 2, should be 0: In scope SELECT pi(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT pi(NULL, NULL);) 2025.09.09 15:09:19.351587 [ 20345 ] {e6dd0ca0-c01a-4f46-a8e5-4d08d022a8f8} TCPHandler: Code: 42. DB::Exception: Number of arguments for function pi doesn't match: passed 2, should be 0: In scope SELECT pi(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:09:19.356227 [ 20849 ] {4c0a237e-b695-4bf6-aed6-da89a0e6849f} executeQuery: Code: 497. DB::Exception: u_03168_query_log_test_ytgucp07: Not enough privileges. To execute this query, it's necessary to have the grant SELECT(a, b) ON test_ytgucp07.d_03168_query_log. (ACCESS_DENIED) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:41868) (comment: 03168_query_log_privileges_not_empty.sh) (in query: select a, b from d_03168_query_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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: 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 @ 0x0000000026dd4032 4. ./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 @ 0x0000000026dd3916 5. ./build_docker/./src/Access/ContextAccess.cpp:687: 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 @ 0x0000000026dd22bb 6. ./build_docker/./src/Access/ContextAccess.cpp:756: DB::ContextAccess::checkAccess(std::shared_ptr const&, DB::AccessFlags const&, std::basic_string_view>, std::basic_string_view>, std::vector> const&) const @ 0x0000000026d947d5 7. ./src/Access/ContextAccess.h:260: DB::Context::checkAccess(DB::AccessFlags const&, DB::StorageID const&, std::vector> const&) const @ 0x0000000028528a04 8. ./build_docker/./src/Planner/PlannerJoinTree.cpp:0: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000002945c0a5 9. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x000000002942c986 10. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x00000000294261fb 11. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000029421552 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1182: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3737e 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 15. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 19. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 20. asan_thread_start(void*) @ 0x000000000aa43059 21. ? @ 0x00007f35aab92ac3 22. ? @ 0x00007f35aac24850 2025.09.09 15:09:19.366339 [ 20849 ] {4c0a237e-b695-4bf6-aed6-da89a0e6849f} TCPHandler: Code: 497. DB::Exception: u_03168_query_log_test_ytgucp07: Not enough privileges. To execute this query, it's necessary to have the grant SELECT(a, b) ON test_ytgucp07.d_03168_query_log. (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: 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 @ 0x0000000026dd4032 4. ./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 @ 0x0000000026dd3916 5. ./build_docker/./src/Access/ContextAccess.cpp:687: 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 @ 0x0000000026dd22bb 6. ./build_docker/./src/Access/ContextAccess.cpp:756: DB::ContextAccess::checkAccess(std::shared_ptr const&, DB::AccessFlags const&, std::basic_string_view>, std::basic_string_view>, std::vector> const&) const @ 0x0000000026d947d5 7. ./src/Access/ContextAccess.h:260: DB::Context::checkAccess(DB::AccessFlags const&, DB::StorageID const&, std::vector> const&) const @ 0x0000000028528a04 8. ./build_docker/./src/Planner/PlannerJoinTree.cpp:0: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000002945c0a5 9. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x000000002942c986 10. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x00000000294261fb 11. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000029421552 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1182: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3737e 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 15. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 19. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 20. asan_thread_start(void*) @ 0x000000000aa43059 21. ? @ 0x00007f35aab92ac3 22. ? @ 0x00007f35aac24850 2025.09.09 15:09:19.396579 [ 3194 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:09:19.480103 [ 3227 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:09:19.920854 [ 3240 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:09:20.126645 [ 20849 ] {6e65e3eb-71d9-49a6-a6ae-23ceff74bbb6} executeQuery: Code: 57. DB::Exception: Table test_1.test_table already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:41880) (comment: 02343_analyzer_column_transformers_strict.sql) (in query: CREATE TABLE test_table ( id UInt64, value 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa91e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1558: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291bc5ff 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291ac835 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000291c3415 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b382fc 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 15. asan_thread_start(void*) @ 0x000000000aa43059 16. ? @ 0x00007f35aab92ac3 17. ? @ 0x00007f35aac24850 2025.09.09 15:09:20.139384 [ 20345 ] {9791cd13-ee2b-4f28-a13e-d982c5805298} executeQuery: Code: 42. DB::Exception: Number of arguments for function polygonAreaCartesian doesn't match: passed 2, should be 1: In scope SELECT polygonAreaCartesian(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT polygonAreaCartesian(NULL, NULL);) 2025.09.09 15:09:20.140469 [ 20849 ] {6e65e3eb-71d9-49a6-a6ae-23ceff74bbb6} TCPHandler: Code: 57. DB::Exception: Table test_1.test_table already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa91e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1558: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291bc5ff 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291ac835 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000291c3415 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b382fc 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 15. asan_thread_start(void*) @ 0x000000000aa43059 16. ? @ 0x00007f35aab92ac3 17. ? @ 0x00007f35aac24850 2025.09.09 15:09:20.155118 [ 20345 ] {9791cd13-ee2b-4f28-a13e-d982c5805298} TCPHandler: Code: 42. DB::Exception: Number of arguments for function polygonAreaCartesian doesn't match: passed 2, should be 1: In scope SELECT polygonAreaCartesian(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:09:20.236449 [ 2748 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:09:20.250677 [ 20345 ] {0181e027-229f-4b6b-8ee3-bc0dc2e710e9} executeQuery: Code: 42. DB::Exception: Number of arguments for function polygonAreaSpherical doesn't match: passed 2, should be 1: In scope SELECT polygonAreaSpherical(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT polygonAreaSpherical(NULL, NULL);) 2025.09.09 15:09:20.261119 [ 20345 ] {0181e027-229f-4b6b-8ee3-bc0dc2e710e9} TCPHandler: Code: 42. DB::Exception: Number of arguments for function polygonAreaSpherical doesn't match: passed 2, should be 1: In scope SELECT polygonAreaSpherical(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:09:20.356993 [ 20345 ] {4052dd6a-f73b-4ce1-9abe-9097c372d2c2} executeQuery: Code: 42. DB::Exception: Number of arguments for function polygonConvexHullCartesian doesn't match: passed 2, should be 1: In scope SELECT polygonConvexHullCartesian(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT polygonConvexHullCartesian(NULL, NULL);) 2025.09.09 15:09:20.366899 [ 20345 ] {4052dd6a-f73b-4ce1-9abe-9097c372d2c2} TCPHandler: Code: 42. DB::Exception: Number of arguments for function polygonConvexHullCartesian doesn't match: passed 2, should be 1: In scope SELECT polygonConvexHullCartesian(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:09:20.400853 [ 3065 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:09:20.471832 [ 20345 ] {fcb51c90-ecbd-4125-98c8-fe6761cf3e11} executeQuery: Code: 42. DB::Exception: Number of arguments for function polygonPerimeterCartesian doesn't match: passed 2, should be 1: In scope SELECT polygonPerimeterCartesian(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT polygonPerimeterCartesian(NULL, NULL);) 2025.09.09 15:09:20.483672 [ 20345 ] {fcb51c90-ecbd-4125-98c8-fe6761cf3e11} TCPHandler: Code: 42. DB::Exception: Number of arguments for function polygonPerimeterCartesian doesn't match: passed 2, should be 1: In scope SELECT polygonPerimeterCartesian(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:09:20.484863 [ 2739 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:09:20.586741 [ 20345 ] {b367f9bf-302d-49f9-b012-646d393d3e16} executeQuery: Code: 42. DB::Exception: Number of arguments for function polygonPerimeterSpherical doesn't match: passed 2, should be 1: In scope SELECT polygonPerimeterSpherical(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT polygonPerimeterSpherical(NULL, NULL);) 2025.09.09 15:09:20.592675 [ 20345 ] {b367f9bf-302d-49f9-b012-646d393d3e16} TCPHandler: Code: 42. DB::Exception: Number of arguments for function polygonPerimeterSpherical doesn't match: passed 2, should be 1: In scope SELECT polygonPerimeterSpherical(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:09:20.922539 [ 2845 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:09:21.240252 [ 2891 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:09:21.403852 [ 2822 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:09:21.491160 [ 2923 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:09:21.715274 [ 3332 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {b2866e3d-697f-407e-a02c-018043ee7457::202509_1_181_63}: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=13, jobs=0). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af80b71 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80746 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002c765aab 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:1197: ? @ 0x000000002c7602b8 8. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x000000002c75fc2b 9. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:0: DB::MergeTreeReaderCompact::MergeTreeReaderCompact(std::shared_ptr, DB::NamesAndTypesList, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*, DB::MarkCache*, DB::MarkRanges, DB::MergeTreeReaderSettings, std::map, std::allocator>>, std::function const&, int) @ 0x000000002c7aee03 10. ./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.h:16: DB::MergeTreeReaderCompactSingleBuffer::MergeTreeReaderCompactSingleBuffer&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int&&) @ 0x000000002c5d6d21 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::MergeTreeDataPartCompact::getReader(DB::NamesAndTypesList const&, std::shared_ptr const&, DB::MarkRanges const&, std::unordered_map, std::equal_to, std::allocator>> const&, DB::UncompressedCache*, DB::MarkCache*, std::shared_ptr const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) const @ 0x000000002c5d1037 12. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:169: DB::MergeTreeSequentialSource::MergeTreeSequentialSource(DB::MergeTreeSequentialSourceType, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::vector>, std::optional, bool, bool, bool) @ 0x000000002c80c330 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:35: DB::MergeTreeSequentialSource* std::construct_at[abi:v15007] const&, std::shared_ptr&, std::shared_ptr&, std::vector>&, std::optional, bool, bool&, bool&, DB::MergeTreeSequentialSource*>(DB::MergeTreeSequentialSource*, DB::MergeTreeSequentialSourceType&, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr&, std::shared_ptr&, std::vector>&, std::optional&&, bool&&, bool&, bool&) @ 0x000000002c81320f 14. ./contrib/llvm-project/libcxx/include/__memory/allocator_traits.h:298: DB::createMergeTreeSequentialSource(DB::MergeTreeSequentialSourceType, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::vector>, std::optional, std::shared_ptr>, bool, bool, bool) @ 0x000000002c810812 15. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1136: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::createMergedStream() @ 0x000000002c3dd079 16. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() @ 0x000000002c3d6516 17. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:534: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x000000002c3e2799 18. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::execute() @ 0x000000002c3ef3fe 19. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:0: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000002cc2f4c0 20. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000002c427f28 21. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000002c429675 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7eaf0 23. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001af8a79f 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 26. asan_thread_start(void*) @ 0x000000000aa43059 27. ? @ 0x00007f35aab92ac3 28. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:09:21.924109 [ 2898 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:09:22.242814 [ 2971 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:09:22.406626 [ 2984 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:09:22.498542 [ 2945 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:09:22.926005 [ 3044 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:09:23.245949 [ 3082 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:09:23.411503 [ 3087 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:09:23.435159 [ 20345 ] {646ef362-73cb-48f7-95ab-1e6cb2827f28} executeQuery: Code: 42. DB::Exception: Number of arguments for function proportionsZTest doesn't match: passed 2, should be 6: In scope SELECT proportionsZTest(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT proportionsZTest(NULL, NULL);) 2025.09.09 15:09:23.444708 [ 20345 ] {646ef362-73cb-48f7-95ab-1e6cb2827f28} TCPHandler: Code: 42. DB::Exception: Number of arguments for function proportionsZTest doesn't match: passed 2, should be 6: In scope SELECT proportionsZTest(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:09:23.500770 [ 3094 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:09:23.512201 [ 20345 ] {003dd7ab-8225-4270-b96c-69d801e4d397} executeQuery: Code: 42. DB::Exception: Number of arguments for function protocol doesn't match: passed 2, should be 1: In scope SELECT protocol(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT protocol(NULL, NULL);) 2025.09.09 15:09:23.516156 [ 20345 ] {003dd7ab-8225-4270-b96c-69d801e4d397} TCPHandler: Code: 42. DB::Exception: Number of arguments for function protocol doesn't match: passed 2, should be 1: In scope SELECT protocol(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:09:23.573196 [ 20345 ] {fc66fa1c-568a-4e3c-b0d8-ba6d5e908274} executeQuery: Code: 42. DB::Exception: Number of arguments for function punycodeDecode doesn't match: passed 2, should be 1: In scope SELECT punycodeDecode(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT punycodeDecode(NULL, NULL);) 2025.09.09 15:09:23.589476 [ 20345 ] {fc66fa1c-568a-4e3c-b0d8-ba6d5e908274} TCPHandler: Code: 42. DB::Exception: Number of arguments for function punycodeDecode doesn't match: passed 2, should be 1: In scope SELECT punycodeDecode(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:09:23.732891 [ 20345 ] {fa87a8c5-c4f3-4c4a-898f-28e3d2e1619f} executeQuery: Code: 42. DB::Exception: Number of arguments for function punycodeEncode doesn't match: passed 2, should be 1: In scope SELECT punycodeEncode(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT punycodeEncode(NULL, NULL);) 2025.09.09 15:09:23.738358 [ 20345 ] {fa87a8c5-c4f3-4c4a-898f-28e3d2e1619f} TCPHandler: Code: 42. DB::Exception: Number of arguments for function punycodeEncode doesn't match: passed 2, should be 1: In scope SELECT punycodeEncode(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:09:23.928342 [ 3152 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:09:24.049281 [ 3722 ] {e6db3d4a-6ca6-41a3-bcd5-fcfd0e283778} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=13, jobs=1): While executing MergeTreeSelect(pool: ReadPool, algorithm: Thread). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:41926) (comment: 03168_query_log_privileges_not_empty.sh) (in query: select used_privileges, missing_privileges from system.query_log where query = 'select a, b from d_03168_query_log' and type = 'ExceptionBeforeStart' and current_database = currentDatabase() 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af80b71 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80746 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002c765aab 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:1197: ? @ 0x000000002c7602b8 8. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x000000002c75fc2b 9. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:0: DB::MergeTreeReaderWide::addStream(DB::ISerialization::SubstreamPath const&, String const&) @ 0x000000002c802c31 10. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:0: void std::__function::__policy_invoker::__call_impl const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x000000002c804a95 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000027a9e455 12. ./src/DataTypes/Serializations/ISerialization.h:225: DB::SerializationLowCardinality::enumerateStreams(DB::ISerialization::EnumerateStreamsSettings&, std::function const&, DB::ISerialization::SubstreamData const&) const @ 0x0000000027b55b9b 13. ./build_docker/./src/DataTypes/Serializations/SerializationArray.cpp:0: DB::SerializationArray::enumerateStreams(DB::ISerialization::EnumerateStreamsSettings&, std::function const&, DB::ISerialization::SubstreamData const&) const @ 0x0000000027ab61b5 14. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:106: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x0000000027a9ea65 15. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:100: DB::MergeTreeReaderWide::addStreams(DB::NameAndTypePair const&, std::shared_ptr const&) @ 0x000000002c7fe815 16. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:0: DB::MergeTreeReaderWide::MergeTreeReaderWide(std::shared_ptr, DB::NamesAndTypesList, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*, DB::MarkCache*, DB::MarkRanges, DB::MergeTreeReaderSettings, std::map, std::allocator>>, std::function const&, int) @ 0x000000002c7fdeea 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) @ 0x000000002c5eb9c6 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 @ 0x000000002c5e354e 19. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:44: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x000000002c82a56b 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:295: DB::MergeTreeReadPoolBase::createTask(std::shared_ptr, DB::MarkRanges, DB::MergeTreeReadTask*) const @ 0x000000002de9c234 21. ./build_docker/./src/Storages/MergeTree/MergeTreeReadPool.cpp:144: DB::MergeTreeReadPool::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x000000002def1bcc 22. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:0: DB::MergeTreeSelectProcessor::read() @ 0x000000002c8241d2 23. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000002de6d77a 24. ./build_docker/./src/Processors/ISource.cpp:0: DB::ISource::work() @ 0x000000002d3290a1 25. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 26. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 27. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:381: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000002d34bd35 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7eaf0 29. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001af8a79f 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 2025.09.09 15:09:24.058665 [ 3722 ] {e6db3d4a-6ca6-41a3-bcd5-fcfd0e283778} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=13, 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af80b71 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80746 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002c765aab 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:1197: ? @ 0x000000002c7602b8 8. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x000000002c75fc2b 9. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:0: DB::MergeTreeReaderWide::addStream(DB::ISerialization::SubstreamPath const&, String const&) @ 0x000000002c802c31 10. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:0: void std::__function::__policy_invoker::__call_impl const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x000000002c804a95 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000027a9e455 12. ./src/DataTypes/Serializations/ISerialization.h:225: DB::SerializationLowCardinality::enumerateStreams(DB::ISerialization::EnumerateStreamsSettings&, std::function const&, DB::ISerialization::SubstreamData const&) const @ 0x0000000027b55b9b 13. ./build_docker/./src/DataTypes/Serializations/SerializationArray.cpp:0: DB::SerializationArray::enumerateStreams(DB::ISerialization::EnumerateStreamsSettings&, std::function const&, DB::ISerialization::SubstreamData const&) const @ 0x0000000027ab61b5 14. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:106: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x0000000027a9ea65 15. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:100: DB::MergeTreeReaderWide::addStreams(DB::NameAndTypePair const&, std::shared_ptr const&) @ 0x000000002c7fe815 16. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:0: DB::MergeTreeReaderWide::MergeTreeReaderWide(std::shared_ptr, DB::NamesAndTypesList, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*, DB::MarkCache*, DB::MarkRanges, DB::MergeTreeReaderSettings, std::map, std::allocator>>, std::function const&, int) @ 0x000000002c7fdeea 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) @ 0x000000002c5eb9c6 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 @ 0x000000002c5e354e 19. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:44: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x000000002c82a56b 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:295: DB::MergeTreeReadPoolBase::createTask(std::shared_ptr, DB::MarkRanges, DB::MergeTreeReadTask*) const @ 0x000000002de9c234 21. ./build_docker/./src/Storages/MergeTree/MergeTreeReadPool.cpp:144: DB::MergeTreeReadPool::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x000000002def1bcc 22. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:0: DB::MergeTreeSelectProcessor::read() @ 0x000000002c8241d2 23. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000002de6d77a 24. ./build_docker/./src/Processors/ISource.cpp:0: DB::ISource::work() @ 0x000000002d3290a1 25. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d362fee 26. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d349dd1 27. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:381: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000002d34bd35 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7eaf0 29. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001af8a79f 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 2025.09.09 15:09:24.248979 [ 3173 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:09:24.413480 [ 3171 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:09:24.503364 [ 3183 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:09:24.930115 [ 3229 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:09:25.251031 [ 2753 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:09:25.330385 [ 20849 ] {3524e7a1-c518-4999-af7e-f10399f2ac7b} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=790, jobs=740). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:41908) (comment: 02366_kql_func_ip.sql) (in query: print '-- ipv4_is_in_range(\'192.168.1.6\', \'192.168.1.1/24\')';), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af872f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af7b2d1 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af7c3f3 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d36920d 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000002d369e5f 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processOrdinaryQuery() @ 0x000000002d18af7b 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d17644a 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 15. asan_thread_start(void*) @ 0x000000000aa43059 16. ? @ 0x00007f35aab92ac3 17. ? @ 0x00007f35aac24850 2025.09.09 15:09:25.333126 [ 20849 ] {3524e7a1-c518-4999-af7e-f10399f2ac7b} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=790, jobs=740). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af872f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af7b2d1 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af7c3f3 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d36920d 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000002d369e5f 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processOrdinaryQuery() @ 0x000000002d18af7b 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d17644a 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 15. asan_thread_start(void*) @ 0x000000000aa43059 16. ? @ 0x00007f35aab92ac3 17. ? @ 0x00007f35aac24850 2025.09.09 15:09:25.415232 [ 2776 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:09:25.505978 [ 2793 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:09:25.816028 [ 20353 ] {bd6959bd-b62e-4781-96f3-7d4b564984d4} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=0, jobs=0). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:41964) (comment: 01155_old_mutation_parts_to_do.sh) (in query: CREATE TABLE rmt (`n` int, `m` int, `s` String) ENGINE = ReplicatedMergeTree('/test/01155_old_mutation_parts_to_do_test_15/rmt', '1') ORDER BY n SETTINGS max_replicated_mutations_in_queue = 0, index_granularity = 57668, min_bytes_for_wide_part = 1073741824, ratio_of_defaults_for_sparse_serialization = 0.3388711214065552, replace_long_file_name_to_hash = false, max_file_name_length = 0, min_bytes_for_full_part_storage = 111198543, compact_parts_max_bytes_to_buffer = 58825027, compact_parts_max_granules_to_buffer = 1, compact_parts_merge_max_bytes_to_prefetch_part = 15793516, merge_max_block_size = 6027, old_parts_lifetime = 97., prefer_fetch_merged_part_size_threshold = 7873103165, vertical_merge_algorithm_min_rows_to_activate = 1000000, vertical_merge_algorithm_min_columns_to_activate = 100, min_merge_bytes_to_use_direct_io = 871330902, index_granularity_bytes = 11777412, concurrent_part_removal_threshold = 100, allow_vertical_merges_from_compact_to_wide_parts = true, cache_populated_by_fetch = true, marks_compress_block_size = 74583, primary_key_compress_block_size = 88310), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af80b71 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80746 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000263a174e 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002c45d4f6 8. ./contrib/llvm-project/libcxx/include/optional:260: DB::StorageReplicatedMergeTree::StorageReplicatedMergeTree(String const&, String const&, DB::LoadingStrictnessLevel, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata const&, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>, DB::RenamingRestrictions, bool) @ 0x000000002ba16434 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:1460: std::shared_ptr std::allocate_shared[abi:v15007], String&, String&, DB::LoadingStrictnessLevel const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, DB::RenamingRestrictions&, bool&, void>(std::allocator const&, String&, String&, DB::LoadingStrictnessLevel const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&, DB::RenamingRestrictions&, bool&) @ 0x000000002cbab63b 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:962: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000002cba1fff 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 @ 0x000000002b77bf53 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291b9254 13. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291ac835 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000291c3415 15. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b382fc 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 18. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 22. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:09:25.820603 [ 20353 ] {bd6959bd-b62e-4781-96f3-7d4b564984d4} 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af80b71 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80746 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000263a174e 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002c45d4f6 8. ./contrib/llvm-project/libcxx/include/optional:260: DB::StorageReplicatedMergeTree::StorageReplicatedMergeTree(String const&, String const&, DB::LoadingStrictnessLevel, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata const&, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>, DB::RenamingRestrictions, bool) @ 0x000000002ba16434 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:1460: std::shared_ptr std::allocate_shared[abi:v15007], String&, String&, DB::LoadingStrictnessLevel const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, DB::RenamingRestrictions&, bool&, void>(std::allocator const&, String&, String&, DB::LoadingStrictnessLevel const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&, DB::RenamingRestrictions&, bool&) @ 0x000000002cbab63b 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:962: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000002cba1fff 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 @ 0x000000002b77bf53 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291b9254 13. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291ac835 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000291c3415 15. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b382fc 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 18. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 22. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:09:25.980498 [ 2875 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:09:26.253122 [ 2900 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:09:26.416892 [ 2917 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:09:26.508957 [ 2928 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:09:26.604344 [ 20881 ] {ce283ae1-4b27-4027-99c7-aa4c98864bb9} executeQuery: Code: 60. DB::Exception: Table test_15.rmt does not exist. (UNKNOWN_TABLE) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:41978) (comment: 01155_old_mutation_parts_to_do.sh) (in query: insert into rmt 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa91e9a 4. ./build_docker/./src/Databases/IDatabase.cpp:37: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000027dd1ade 5. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000286af00b 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000286bb117 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000002934b836 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:748: DB::InterpreterInsertQuery::execute() @ 0x000000002935ad49 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b382fc 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 15:09:26.611901 [ 20345 ] {b0734678-bb93-4fc8-bc9a-f99d7112a3ad} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=1, jobs=1). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT quantileTimingWeighted(NULL, NULL);) 2025.09.09 15:09:26.632329 [ 20881 ] {ce283ae1-4b27-4027-99c7-aa4c98864bb9} TCPHandler: Code: 60. DB::Exception: Table test_15.rmt 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa91e9a 4. ./build_docker/./src/Databases/IDatabase.cpp:37: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000027dd1ade 5. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000286af00b 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000286bb117 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000002934b836 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:748: DB::InterpreterInsertQuery::execute() @ 0x000000002935ad49 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b382fc 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 15:09:26.635721 [ 20345 ] {b0734678-bb93-4fc8-bc9a-f99d7112a3ad} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=1, jobs=1). (CANNOT_SCHEDULE_TASK) 2025.09.09 15:09:26.801567 [ 20345 ] {ece5ba16-4707-45bd-aa4d-ffb523aa91da} executeQuery: Code: 43. DB::Exception: Illegal type Nullable(Nothing) of argument for aggregate function quantiles. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT quantiles(NULL, NULL);) 2025.09.09 15:09:26.807981 [ 20345 ] {ece5ba16-4707-45bd-aa4d-ffb523aa91da} TCPHandler: Code: 43. DB::Exception: Illegal type Nullable(Nothing) of argument for aggregate function quantiles. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.09.09 15:09:26.865019 [ 20345 ] {b455b7db-d151-48e5-83cc-018280e98346} executeQuery: Code: 43. DB::Exception: Illegal type Nullable(Nothing) of argument for aggregate function quantilesBFloat16. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT quantilesBFloat16(NULL, NULL);) 2025.09.09 15:09:26.874993 [ 20345 ] {b455b7db-d151-48e5-83cc-018280e98346} TCPHandler: Code: 43. DB::Exception: Illegal type Nullable(Nothing) of argument for aggregate function quantilesBFloat16. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.09.09 15:09:26.982756 [ 2887 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:09:27.216148 [ 20345 ] {7e8cb79a-5128-4643-add5-73035554cc7b} executeQuery: Code: 43. DB::Exception: Illegal type Nullable(Nothing) of argument for aggregate function quantilesDD. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT quantilesDD(NULL, NULL);) 2025.09.09 15:09:27.229523 [ 20345 ] {7e8cb79a-5128-4643-add5-73035554cc7b} TCPHandler: Code: 43. DB::Exception: Illegal type Nullable(Nothing) of argument for aggregate function quantilesDD. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.09.09 15:09:27.256481 [ 2861 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:09:27.347984 [ 20345 ] {9096cdb1-3a30-44a5-b305-0710bd452f30} executeQuery: Code: 43. DB::Exception: Illegal type Nullable(Nothing) of argument for aggregate function quantilesDeterministic. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT quantilesDeterministic(NULL, NULL);) 2025.09.09 15:09:27.360956 [ 20353 ] {00f4efcb-56a4-476d-aff8-07c726e3db93} executeQuery: Code: 60. DB::Exception: Could not find table: rmt. (UNKNOWN_TABLE) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:42004) (comment: 01155_old_mutation_parts_to_do.sh) (in query: alter table rmt update m = m*toInt8(s) where 1;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x000000000aafc574 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:127: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000291758a0 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x0000000029170711 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b382fc 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 9. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 13. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 14. asan_thread_start(void*) @ 0x000000000aa43059 15. ? @ 0x00007f35aab92ac3 16. ? @ 0x00007f35aac24850 2025.09.09 15:09:27.364625 [ 20345 ] {9096cdb1-3a30-44a5-b305-0710bd452f30} TCPHandler: Code: 43. DB::Exception: Illegal type Nullable(Nothing) of argument for aggregate function quantilesDeterministic. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.09.09 15:09:27.370748 [ 20353 ] {00f4efcb-56a4-476d-aff8-07c726e3db93} TCPHandler: Code: 60. DB::Exception: Could not find table: rmt. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x000000000aafc574 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:127: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000291758a0 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x0000000029170711 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b382fc 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 9. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 13. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 14. asan_thread_start(void*) @ 0x000000000aa43059 15. ? @ 0x00007f35aab92ac3 16. ? @ 0x00007f35aac24850 2025.09.09 15:09:27.419687 [ 2893 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:09:27.447313 [ 19252 ] {3872f3ae-f0e6-4c68-9408-4a785863be86} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:44872) (comment: 03168_query_log_privileges_not_empty.sh) (in query: DROP DATABASE IF EXISTS test_ytgucp07 ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aac868e 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x00000000286b57c7 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x00000000291f5630 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:361: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000291edc97 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x00000000291ebf11 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x00000000291eb7ed 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b382fc 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1529: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000029b3ed3f 11. ./build_docker/./src/Server/HTTPHandler.cpp:529: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000002d0662d1 12. ./build_docker/./src/Server/HTTPHandler.cpp:705: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000002d06d139 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000002d1cc337 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 18. asan_thread_start(void*) @ 0x000000000aa43059 19. ? @ 0x00007f35aab92ac3 20. ? @ 0x00007f35aac24850 2025.09.09 15:09:27.451967 [ 19252 ] {3872f3ae-f0e6-4c68-9408-4a785863be86} DynamicQueryHandler: Code: 219. DB::Exception: New table 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aac868e 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x00000000286b57c7 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x00000000291f5630 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:361: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000291edc97 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x00000000291ebf11 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x00000000291eb7ed 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b382fc 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1529: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000029b3ed3f 11. ./build_docker/./src/Server/HTTPHandler.cpp:529: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000002d0662d1 12. ./build_docker/./src/Server/HTTPHandler.cpp:705: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000002d06d139 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000002d1cc337 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 18. asan_thread_start(void*) @ 0x000000000aa43059 19. ? @ 0x00007f35aab92ac3 20. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:09:27.461136 [ 20345 ] {41e71fe4-62ae-4bdb-b9c4-3f50747b29d1} executeQuery: Code: 43. DB::Exception: Illegal type Nullable(Nothing) of argument for aggregate function quantilesExact. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT quantilesExact(NULL, NULL);) 2025.09.09 15:09:27.467808 [ 20345 ] {41e71fe4-62ae-4bdb-b9c4-3f50747b29d1} TCPHandler: Code: 43. DB::Exception: Illegal type Nullable(Nothing) of argument for aggregate function quantilesExact. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.09.09 15:09:27.511960 [ 2884 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:09:27.588735 [ 20345 ] {6b0eead8-642b-43e1-b308-ae85b9490f6f} executeQuery: Code: 43. DB::Exception: Illegal type Nullable(Nothing) of argument for aggregate function quantilesExactExclusive. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT quantilesExactExclusive(NULL, NULL);) 2025.09.09 15:09:27.607440 [ 20345 ] {6b0eead8-642b-43e1-b308-ae85b9490f6f} TCPHandler: Code: 43. DB::Exception: Illegal type Nullable(Nothing) of argument for aggregate function quantilesExactExclusive. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.09.09 15:09:27.657283 [ 20345 ] {a1da2086-2222-412f-8d0d-5c155abe01cb} executeQuery: Code: 43. DB::Exception: Illegal type Nullable(Nothing) of argument for aggregate function quantilesExactHigh. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT quantilesExactHigh(NULL, NULL);) 2025.09.09 15:09:27.661653 [ 20345 ] {a1da2086-2222-412f-8d0d-5c155abe01cb} TCPHandler: Code: 43. DB::Exception: Illegal type Nullable(Nothing) of argument for aggregate function quantilesExactHigh. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.09.09 15:09:27.755981 [ 20345 ] {72aefaec-5aaa-4d3b-9e59-2d180e5ddfe0} executeQuery: Code: 43. DB::Exception: Illegal type Nullable(Nothing) of argument for aggregate function quantilesExactInclusive. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT quantilesExactInclusive(NULL, NULL);) 2025.09.09 15:09:27.758807 [ 20345 ] {72aefaec-5aaa-4d3b-9e59-2d180e5ddfe0} TCPHandler: Code: 43. DB::Exception: Illegal type Nullable(Nothing) of argument for aggregate function quantilesExactInclusive. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.09.09 15:09:27.835291 [ 20345 ] {6a43c4e4-f71b-4c72-bca6-441b00e65886} executeQuery: Code: 43. DB::Exception: Illegal type Nullable(Nothing) of argument for aggregate function quantilesExactLow. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT quantilesExactLow(NULL, NULL);) 2025.09.09 15:09:27.846992 [ 20345 ] {6a43c4e4-f71b-4c72-bca6-441b00e65886} TCPHandler: Code: 43. DB::Exception: Illegal type Nullable(Nothing) of argument for aggregate function quantilesExactLow. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.09.09 15:09:27.977735 [ 20345 ] {cfbc8150-8ed6-4107-927a-b997a07768af} executeQuery: Code: 43. DB::Exception: Illegal type Nullable(Nothing) of argument for aggregate function quantilesExactWeighted. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT quantilesExactWeighted(NULL, NULL);) 2025.09.09 15:09:27.983702 [ 20345 ] {cfbc8150-8ed6-4107-927a-b997a07768af} TCPHandler: Code: 43. DB::Exception: Illegal type Nullable(Nothing) of argument for aggregate function quantilesExactWeighted. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.09.09 15:09:27.985303 [ 2947 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:09:28.065552 [ 20345 ] {446baf0d-e50d-4905-b883-371e2f9c0c8a} executeQuery: Code: 43. DB::Exception: Illegal type Nullable(Nothing) of argument for aggregate function quantilesGK. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT quantilesGK(NULL, NULL);) 2025.09.09 15:09:28.069610 [ 20345 ] {446baf0d-e50d-4905-b883-371e2f9c0c8a} TCPHandler: Code: 43. DB::Exception: Illegal type Nullable(Nothing) of argument for aggregate function quantilesGK. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.09.09 15:09:28.181292 [ 20345 ] {cf1bbfea-eb0c-4664-b947-997ad5eddf73} executeQuery: Code: 43. DB::Exception: Illegal type Nullable(Nothing) of argument for aggregate function quantilesInterpolatedWeighted. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT quantilesInterpolatedWeighted(NULL, NULL);) 2025.09.09 15:09:28.185217 [ 20345 ] {cf1bbfea-eb0c-4664-b947-997ad5eddf73} TCPHandler: Code: 43. DB::Exception: Illegal type Nullable(Nothing) of argument for aggregate function quantilesInterpolatedWeighted. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.09.09 15:09:28.228207 [ 20345 ] {20952644-78ef-424d-b765-bd4fc632a69a} executeQuery: Code: 43. DB::Exception: Illegal type Nullable(Nothing) of argument for aggregate function quantilesTDigest. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT quantilesTDigest(NULL, NULL);) 2025.09.09 15:09:28.232729 [ 20345 ] {20952644-78ef-424d-b765-bd4fc632a69a} TCPHandler: Code: 43. DB::Exception: Illegal type Nullable(Nothing) of argument for aggregate function quantilesTDigest. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.09.09 15:09:28.258672 [ 2965 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:09:28.263951 [ 20351 ] {3ef0e8b5-f905-43b4-b13a-21a9a1a11405} executeQuery: Code: 60. DB::Exception: Table test_15.rmt does not exist. (UNKNOWN_TABLE) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:50594) (comment: 01155_old_mutation_parts_to_do.sh) (in query: insert into rmt 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa91e9a 4. ./build_docker/./src/Databases/IDatabase.cpp:37: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000027dd1ade 5. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000286af00b 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000286bb117 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000002934b836 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:748: DB::InterpreterInsertQuery::execute() @ 0x000000002935ad49 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b382fc 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 15:09:28.265958 [ 20351 ] {3ef0e8b5-f905-43b4-b13a-21a9a1a11405} TCPHandler: Code: 60. DB::Exception: Table test_15.rmt 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa91e9a 4. ./build_docker/./src/Databases/IDatabase.cpp:37: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000027dd1ade 5. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000286af00b 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000286bb117 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000002934b836 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:748: DB::InterpreterInsertQuery::execute() @ 0x000000002935ad49 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b382fc 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 15:09:28.284798 [ 20345 ] {c416716c-7bba-4b38-9010-da6f2e0499af} executeQuery: Code: 43. DB::Exception: Illegal type Nullable(Nothing) of argument for aggregate function quantilesTDigestWeighted. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT quantilesTDigestWeighted(NULL, NULL);) 2025.09.09 15:09:28.395887 [ 20345 ] {c416716c-7bba-4b38-9010-da6f2e0499af} TCPHandler: Code: 43. DB::Exception: Illegal type Nullable(Nothing) of argument for aggregate function quantilesTDigestWeighted. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.09.09 15:09:28.422047 [ 3001 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:09:28.455476 [ 20345 ] {da968f0e-98f5-4997-89aa-118319e533d5} executeQuery: Code: 43. DB::Exception: Illegal type Nullable(Nothing) of argument for aggregate function quantilesTiming. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT quantilesTiming(NULL, NULL);) 2025.09.09 15:09:28.474368 [ 20345 ] {da968f0e-98f5-4997-89aa-118319e533d5} TCPHandler: Code: 43. DB::Exception: Illegal type Nullable(Nothing) of argument for aggregate function quantilesTiming. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.09.09 15:09:28.514950 [ 3030 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:09:28.567011 [ 20345 ] {f647c90f-e031-413d-b966-28d7b6d08aa7} executeQuery: Code: 43. DB::Exception: Illegal type Nullable(Nothing) of argument for aggregate function quantilesTimingWeighted. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT quantilesTimingWeighted(NULL, NULL);) 2025.09.09 15:09:28.572006 [ 20345 ] {f647c90f-e031-413d-b966-28d7b6d08aa7} TCPHandler: Code: 43. DB::Exception: Illegal type Nullable(Nothing) of argument for aggregate function quantilesTimingWeighted. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.09.09 15:09:28.669652 [ 20345 ] {a854d6a0-df6d-4f5d-a5b5-df661f0696a4} executeQuery: Code: 42. DB::Exception: Number of arguments for function queryID doesn't match: passed 2, should be 0: In scope SELECT queryID(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT queryID(NULL, NULL);) 2025.09.09 15:09:28.693018 [ 20345 ] {a854d6a0-df6d-4f5d-a5b5-df661f0696a4} TCPHandler: Code: 42. DB::Exception: Number of arguments for function queryID doesn't match: passed 2, should be 0: In scope SELECT queryID(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:09:28.792830 [ 20345 ] {b37ef9b4-396c-4998-856a-073cae074e28} executeQuery: Code: 42. DB::Exception: Number of arguments for function queryString doesn't match: passed 2, should be 1: In scope SELECT queryString(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT queryString(NULL, NULL);) 2025.09.09 15:09:28.798555 [ 20345 ] {b37ef9b4-396c-4998-856a-073cae074e28} TCPHandler: Code: 42. DB::Exception: Number of arguments for function queryString doesn't match: passed 2, should be 1: In scope SELECT queryString(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:09:28.988059 [ 3049 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:09:28.992214 [ 20345 ] {ba8db35d-d13d-4e7c-88fb-0789de0c88b1} executeQuery: Code: 42. DB::Exception: Number of arguments for function queryStringAndFragment doesn't match: passed 2, should be 1: In scope SELECT queryStringAndFragment(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT queryStringAndFragment(NULL, NULL);) 2025.09.09 15:09:28.999760 [ 20345 ] {ba8db35d-d13d-4e7c-88fb-0789de0c88b1} TCPHandler: Code: 42. DB::Exception: Number of arguments for function queryStringAndFragment doesn't match: passed 2, should be 1: In scope SELECT queryStringAndFragment(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:09:29.104942 [ 20351 ] {4774812f-e197-4cf7-ba67-fdad12c5b61c} executeQuery: Code: 60. DB::Exception: Could not find table: rmt. (UNKNOWN_TABLE) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:50598) (comment: 01155_old_mutation_parts_to_do.sh) (in query: alter table rmt update m = m*toInt8(s) where 1;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x000000000aafc574 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:127: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000291758a0 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x0000000029170711 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b382fc 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 9. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 13. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 14. asan_thread_start(void*) @ 0x000000000aa43059 15. ? @ 0x00007f35aab92ac3 16. ? @ 0x00007f35aac24850 2025.09.09 15:09:29.114620 [ 20351 ] {4774812f-e197-4cf7-ba67-fdad12c5b61c} TCPHandler: Code: 60. DB::Exception: Could not find table: rmt. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x000000000aafc574 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:127: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000291758a0 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x0000000029170711 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b382fc 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 9. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 13. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 14. asan_thread_start(void*) @ 0x000000000aa43059 15. ? @ 0x00007f35aab92ac3 16. ? @ 0x00007f35aac24850 2025.09.09 15:09:29.148827 [ 20345 ] {0f4f5d3b-1c07-44c7-bcb7-aa125ff21225} executeQuery: Code: 42. DB::Exception: Number of arguments for function queryID doesn't match: passed 2, should be 0: In scope SELECT query_id(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT query_id(NULL, NULL);) 2025.09.09 15:09:29.159800 [ 20345 ] {0f4f5d3b-1c07-44c7-bcb7-aa125ff21225} TCPHandler: Code: 42. DB::Exception: Number of arguments for function queryID doesn't match: passed 2, should be 0: In scope SELECT query_id(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:09:29.269720 [ 3105 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:09:29.309547 [ 20345 ] {04face93-847b-4dc4-a2c7-79dd1d469190} executeQuery: Code: 42. DB::Exception: Number of arguments for function radians doesn't match: passed 2, should be 1: In scope SELECT radians(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT radians(NULL, NULL);) 2025.09.09 15:09:29.329924 [ 20345 ] {04face93-847b-4dc4-a2c7-79dd1d469190} TCPHandler: Code: 42. DB::Exception: Number of arguments for function radians doesn't match: passed 2, should be 1: In scope SELECT radians(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:09:29.424042 [ 3112 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:09:29.458351 [ 20345 ] {f3cf9042-cf60-47bf-9be6-1ad37fb053aa} executeQuery: Code: 42. DB::Exception: Number of arguments for function rand doesn't match: passed 2, should be 0 or 1.: In scope SELECT rand(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT rand(NULL, NULL);) 2025.09.09 15:09:29.463051 [ 20345 ] {f3cf9042-cf60-47bf-9be6-1ad37fb053aa} TCPHandler: Code: 42. DB::Exception: Number of arguments for function rand doesn't match: passed 2, should be 0 or 1.: In scope SELECT rand(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:09:29.517613 [ 3087 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:09:29.558892 [ 20345 ] {d55380a7-8f02-4547-8dfd-076baf0b39f1} executeQuery: Code: 42. DB::Exception: Number of arguments for function rand doesn't match: passed 2, should be 0 or 1.: In scope SELECT rand32(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT rand32(NULL, NULL);) 2025.09.09 15:09:29.564632 [ 20345 ] {d55380a7-8f02-4547-8dfd-076baf0b39f1} TCPHandler: Code: 42. DB::Exception: Number of arguments for function rand doesn't match: passed 2, should be 0 or 1.: In scope SELECT rand32(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:09:29.651056 [ 20345 ] {c7b671ef-6926-4678-b534-1768a1116ad1} executeQuery: Code: 42. DB::Exception: Number of arguments for function rand64 doesn't match: passed 2, should be 0 or 1.: In scope SELECT rand64(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT rand64(NULL, NULL);) 2025.09.09 15:09:29.657799 [ 20345 ] {c7b671ef-6926-4678-b534-1768a1116ad1} TCPHandler: Code: 42. DB::Exception: Number of arguments for function rand64 doesn't match: passed 2, should be 0 or 1.: In scope SELECT rand64(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:09:29.827701 [ 20351 ] {bd9ea8b5-a154-4faa-9a45-1ea6db6bc22a} executeQuery: Code: 60. DB::Exception: Table test_15.rmt does not exist. (UNKNOWN_TABLE) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:50622) (comment: 01155_old_mutation_parts_to_do.sh) (in query: insert into rmt 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa91e9a 4. ./build_docker/./src/Databases/IDatabase.cpp:37: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000027dd1ade 5. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000286af00b 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000286bb117 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000002934b836 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:748: DB::InterpreterInsertQuery::execute() @ 0x000000002935ad49 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b382fc 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 15:09:29.845662 [ 20351 ] {bd9ea8b5-a154-4faa-9a45-1ea6db6bc22a} TCPHandler: Code: 60. DB::Exception: Table test_15.rmt 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa91e9a 4. ./build_docker/./src/Databases/IDatabase.cpp:37: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000027dd1ade 5. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000286af00b 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000286bb117 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000002934b836 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:748: DB::InterpreterInsertQuery::execute() @ 0x000000002935ad49 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b382fc 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 15:09:29.992238 [ 3145 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:09:29.998292 [ 5444 ] {2f043b8c-e50a-4a52-807e-ad70db70e836} ExternalDictionariesLoader: Could not update external dictionary 'd35b730f-cdc5-42a8-9c4e-56577d718dc0', leaving the previous version: Code: 489. DB::Exception: Cannot parse abcde for data type Int64, Reason is: Code: 632. DB::Exception: Unexpected data 'abcde' after parsed Number value '0'. (UNEXPECTED_DATA_AFTER_PARSED_VALUE) (version 24.8.14.10505.altinitytest (altinity build)). (INCORRECT_DICTIONARY_DEFINITION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, String&&, String&&) @ 0x000000000b578ce0 4. ./build_docker/./src/Dictionaries/RegExpTreeDictionary.cpp:85: DB::(anonymous namespace)::parseStringToField(String const&, std::shared_ptr) @ 0x000000001b6e9c30 5. ./build_docker/./src/Dictionaries/RegExpTreeDictionary.cpp:0: DB::RegExpTreeDictionary::initRegexNodes(DB::Block&) @ 0x000000001b6e55e8 6. ./build_docker/./src/Dictionaries/RegExpTreeDictionary.cpp:321: DB::RegExpTreeDictionary::loadData() @ 0x000000001b6eb545 7. ./build_docker/./src/Dictionaries/RegExpTreeDictionary.cpp:0: DB::RegExpTreeDictionary::RegExpTreeDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::RegExpTreeDictionary::Configuration, bool, bool, bool) @ 0x000000001b6ef15e 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: 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) @ 0x000000001b6ffd5d 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 10. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 12. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 13. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 16. asan_thread_start(void*) @ 0x000000000aa43059 17. ? @ 0x00007f35aab92ac3 18. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:09:30.005683 [ 20881 ] {2f043b8c-e50a-4a52-807e-ad70db70e836} executeQuery: Code: 489. DB::Exception: Cannot parse abcde for data type Int64, Reason is: Code: 632. DB::Exception: Unexpected data 'abcde' after parsed Number value '0'. (UNEXPECTED_DATA_AFTER_PARSED_VALUE) (version 24.8.14.10505.altinitytest (altinity build)). (INCORRECT_DICTIONARY_DEFINITION) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:50606) (comment: 02504_regexp_dictionary_yaml_source.sh) (in query: system reload dictionary regexp_dict1;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, String&&, String&&) @ 0x000000000b578ce0 4. ./build_docker/./src/Dictionaries/RegExpTreeDictionary.cpp:85: DB::(anonymous namespace)::parseStringToField(String const&, std::shared_ptr) @ 0x000000001b6e9c30 5. ./build_docker/./src/Dictionaries/RegExpTreeDictionary.cpp:0: DB::RegExpTreeDictionary::initRegexNodes(DB::Block&) @ 0x000000001b6e55e8 6. ./build_docker/./src/Dictionaries/RegExpTreeDictionary.cpp:321: DB::RegExpTreeDictionary::loadData() @ 0x000000001b6eb545 7. ./build_docker/./src/Dictionaries/RegExpTreeDictionary.cpp:0: DB::RegExpTreeDictionary::RegExpTreeDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::RegExpTreeDictionary::Configuration, bool, bool, bool) @ 0x000000001b6ef15e 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: 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) @ 0x000000001b6ffd5d 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 10. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 12. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 13. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 16. asan_thread_start(void*) @ 0x000000000aa43059 17. ? @ 0x00007f35aab92ac3 18. ? @ 0x00007f35aac24850 2025.09.09 15:09:30.007485 [ 20881 ] {2f043b8c-e50a-4a52-807e-ad70db70e836} TCPHandler: Code: 489. DB::Exception: Cannot parse abcde for data type Int64, Reason is: Code: 632. DB::Exception: Unexpected data 'abcde' after parsed Number value '0'. (UNEXPECTED_DATA_AFTER_PARSED_VALUE) (version 24.8.14.10505.altinitytest (altinity build)). (INCORRECT_DICTIONARY_DEFINITION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, String&&, String&&) @ 0x000000000b578ce0 4. ./build_docker/./src/Dictionaries/RegExpTreeDictionary.cpp:85: DB::(anonymous namespace)::parseStringToField(String const&, std::shared_ptr) @ 0x000000001b6e9c30 5. ./build_docker/./src/Dictionaries/RegExpTreeDictionary.cpp:0: DB::RegExpTreeDictionary::initRegexNodes(DB::Block&) @ 0x000000001b6e55e8 6. ./build_docker/./src/Dictionaries/RegExpTreeDictionary.cpp:321: DB::RegExpTreeDictionary::loadData() @ 0x000000001b6eb545 7. ./build_docker/./src/Dictionaries/RegExpTreeDictionary.cpp:0: DB::RegExpTreeDictionary::RegExpTreeDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::RegExpTreeDictionary::Configuration, bool, bool, bool) @ 0x000000001b6ef15e 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: 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) @ 0x000000001b6ffd5d 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 10. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 12. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 13. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 16. asan_thread_start(void*) @ 0x000000000aa43059 17. ? @ 0x00007f35aab92ac3 18. ? @ 0x00007f35aac24850 2025.09.09 15:09:30.089655 [ 20345 ] {2d4f243f-a4c7-4d5a-a182-c465e9a2219b} executeQuery: Code: 42. DB::Exception: Number of arguments for function randCanonical doesn't match: passed 2, should be 0 or 1.: In scope SELECT randCanonical(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT randCanonical(NULL, NULL);) 2025.09.09 15:09:30.114235 [ 20345 ] {2d4f243f-a4c7-4d5a-a182-c465e9a2219b} TCPHandler: Code: 42. DB::Exception: Number of arguments for function randCanonical doesn't match: passed 2, should be 0 or 1.: In scope SELECT randCanonical(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:09:30.272407 [ 3186 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:09:30.293110 [ 20345 ] {be6307d4-d2d2-4f6c-91c6-33bdff5a0aef} executeQuery: Code: 42. DB::Exception: Number of arguments for function randConstant doesn't match: passed 2, should be 0 or 1.: In scope SELECT randConstant(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT randConstant(NULL, NULL);) 2025.09.09 15:09:30.297795 [ 20345 ] {be6307d4-d2d2-4f6c-91c6-33bdff5a0aef} TCPHandler: Code: 42. DB::Exception: Number of arguments for function randConstant doesn't match: passed 2, should be 0 or 1.: In scope SELECT randConstant(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:09:30.427020 [ 3214 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:09:30.517417 [ 20351 ] {b267e93e-c8b2-4ad0-ab87-84283767529c} executeQuery: Code: 60. DB::Exception: Could not find table: rmt. (UNKNOWN_TABLE) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:50632) (comment: 01155_old_mutation_parts_to_do.sh) (in query: alter table rmt update m = m*toInt8(s) where n=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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x000000000aafc574 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:127: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000291758a0 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x0000000029170711 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b382fc 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 9. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 13. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 14. asan_thread_start(void*) @ 0x000000000aa43059 15. ? @ 0x00007f35aab92ac3 16. ? @ 0x00007f35aac24850 2025.09.09 15:09:30.520552 [ 3189 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:09:30.528942 [ 20351 ] {b267e93e-c8b2-4ad0-ab87-84283767529c} TCPHandler: Code: 60. DB::Exception: Could not find table: rmt. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x000000000aafc574 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:127: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000291758a0 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x0000000029170711 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b382fc 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 9. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 13. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 14. asan_thread_start(void*) @ 0x000000000aa43059 15. ? @ 0x00007f35aab92ac3 16. ? @ 0x00007f35aac24850 2025.09.09 15:09:30.993937 [ 3217 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:09:31.074370 [ 9286 ] {9c2b8d2a-62e4-429c-a395-12eda7308c0a} ExternalDictionariesLoader: Could not update external dictionary 'd35b730f-cdc5-42a8-9c4e-56577d718dc0', leaving the previous version: Code: 318. DB::Exception: `regexp` should be a String. (INVALID_CONFIG_PARAMETER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Dictionaries/YAMLRegExpTreeDictionarySource.cpp:237: DB::parseMatchNode(unsigned long, unsigned long&, YAML::Node const&, DB::ResultColumns&, String const&, DB::DictionaryStructure const&) @ 0x000000001b5a935f 5. ./build_docker/./src/Dictionaries/YAMLRegExpTreeDictionarySource.cpp:265: DB::parseMatchList(unsigned long, unsigned long&, YAML::Node const&, DB::ResultColumns&, String const&, DB::DictionaryStructure const&) @ 0x000000001b5aa18e 6. ./build_docker/./src/Dictionaries/YAMLRegExpTreeDictionarySource.cpp:0: DB::parseYAMLAsRegExpTree(YAML::Node const&, String const&, DB::DictionaryStructure const&) @ 0x000000001b5aa9bd 7. ./contrib/llvm-project/libcxx/include/new:246: DB::YAMLRegExpTreeDictionarySource::loadAll() @ 0x000000001b5adf76 8. ./build_docker/./src/Dictionaries/RegExpTreeDictionary.cpp:0: DB::RegExpTreeDictionary::loadData() @ 0x000000001b6eb3d6 9. ./build_docker/./src/Dictionaries/RegExpTreeDictionary.cpp:0: DB::RegExpTreeDictionary::RegExpTreeDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::RegExpTreeDictionary::Configuration, bool, bool, bool) @ 0x000000001b6ef15e 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: 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) @ 0x000000001b6ffd5d 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 12. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 13. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 14. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 15. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 18. asan_thread_start(void*) @ 0x000000000aa43059 19. ? @ 0x00007f35aab92ac3 20. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:09:31.079442 [ 20881 ] {9c2b8d2a-62e4-429c-a395-12eda7308c0a} executeQuery: Code: 318. DB::Exception: `regexp` should be a String. (INVALID_CONFIG_PARAMETER) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:50636) (comment: 02504_regexp_dictionary_yaml_source.sh) (in query: system reload dictionary regexp_dict1;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Dictionaries/YAMLRegExpTreeDictionarySource.cpp:237: DB::parseMatchNode(unsigned long, unsigned long&, YAML::Node const&, DB::ResultColumns&, String const&, DB::DictionaryStructure const&) @ 0x000000001b5a935f 5. ./build_docker/./src/Dictionaries/YAMLRegExpTreeDictionarySource.cpp:265: DB::parseMatchList(unsigned long, unsigned long&, YAML::Node const&, DB::ResultColumns&, String const&, DB::DictionaryStructure const&) @ 0x000000001b5aa18e 6. ./build_docker/./src/Dictionaries/YAMLRegExpTreeDictionarySource.cpp:0: DB::parseYAMLAsRegExpTree(YAML::Node const&, String const&, DB::DictionaryStructure const&) @ 0x000000001b5aa9bd 7. ./contrib/llvm-project/libcxx/include/new:246: DB::YAMLRegExpTreeDictionarySource::loadAll() @ 0x000000001b5adf76 8. ./build_docker/./src/Dictionaries/RegExpTreeDictionary.cpp:0: DB::RegExpTreeDictionary::loadData() @ 0x000000001b6eb3d6 9. ./build_docker/./src/Dictionaries/RegExpTreeDictionary.cpp:0: DB::RegExpTreeDictionary::RegExpTreeDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::RegExpTreeDictionary::Configuration, bool, bool, bool) @ 0x000000001b6ef15e 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: 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) @ 0x000000001b6ffd5d 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 12. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 13. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 14. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 15. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 18. asan_thread_start(void*) @ 0x000000000aa43059 19. ? @ 0x00007f35aab92ac3 20. ? @ 0x00007f35aac24850 2025.09.09 15:09:31.083653 [ 20881 ] {9c2b8d2a-62e4-429c-a395-12eda7308c0a} TCPHandler: Code: 318. DB::Exception: `regexp` should be a String. (INVALID_CONFIG_PARAMETER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Dictionaries/YAMLRegExpTreeDictionarySource.cpp:237: DB::parseMatchNode(unsigned long, unsigned long&, YAML::Node const&, DB::ResultColumns&, String const&, DB::DictionaryStructure const&) @ 0x000000001b5a935f 5. ./build_docker/./src/Dictionaries/YAMLRegExpTreeDictionarySource.cpp:265: DB::parseMatchList(unsigned long, unsigned long&, YAML::Node const&, DB::ResultColumns&, String const&, DB::DictionaryStructure const&) @ 0x000000001b5aa18e 6. ./build_docker/./src/Dictionaries/YAMLRegExpTreeDictionarySource.cpp:0: DB::parseYAMLAsRegExpTree(YAML::Node const&, String const&, DB::DictionaryStructure const&) @ 0x000000001b5aa9bd 7. ./contrib/llvm-project/libcxx/include/new:246: DB::YAMLRegExpTreeDictionarySource::loadAll() @ 0x000000001b5adf76 8. ./build_docker/./src/Dictionaries/RegExpTreeDictionary.cpp:0: DB::RegExpTreeDictionary::loadData() @ 0x000000001b6eb3d6 9. ./build_docker/./src/Dictionaries/RegExpTreeDictionary.cpp:0: DB::RegExpTreeDictionary::RegExpTreeDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::RegExpTreeDictionary::Configuration, bool, bool, bool) @ 0x000000001b6ef15e 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: 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) @ 0x000000001b6ffd5d 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000026596ab5 12. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:43: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000290ec35a 13. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000291079d6 14. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000029100aea 15. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x000000002910e271 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 18. asan_thread_start(void*) @ 0x000000000aa43059 19. ? @ 0x00007f35aab92ac3 20. ? @ 0x00007f35aac24850 2025.09.09 15:09:31.243712 [ 20379 ] {aad86029-38c9-44e4-a3fc-7d2f727cc31d} executeQuery: Code: 60. DB::Exception: Table test_15.rmt does not exist. (UNKNOWN_TABLE) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:50654) (comment: 01155_old_mutation_parts_to_do.sh) (in query: insert into rmt 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa91e9a 4. ./build_docker/./src/Databases/IDatabase.cpp:37: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000027dd1ade 5. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000286af00b 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000286bb117 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000002934b836 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:748: DB::InterpreterInsertQuery::execute() @ 0x000000002935ad49 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b382fc 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 15:09:31.261523 [ 20379 ] {aad86029-38c9-44e4-a3fc-7d2f727cc31d} TCPHandler: Code: 60. DB::Exception: Table test_15.rmt 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa91e9a 4. ./build_docker/./src/Databases/IDatabase.cpp:37: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000027dd1ade 5. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000286af00b 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000286bb117 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000002934b836 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:748: DB::InterpreterInsertQuery::execute() @ 0x000000002935ad49 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b382fc 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 15:09:31.275050 [ 2732 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:09:31.430274 [ 2743 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:09:31.523319 [ 2762 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:09:31.717461 [ 20345 ] {31d0c920-89e2-4376-8b08-fff601e76d98} executeQuery: Code: 42. DB::Exception: Number of arguments for function randomFixedString doesn't match: passed 2, should be 1: In scope SELECT randomFixedString(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT randomFixedString(NULL, NULL);) 2025.09.09 15:09:31.722640 [ 20345 ] {31d0c920-89e2-4376-8b08-fff601e76d98} TCPHandler: Code: 42. DB::Exception: Number of arguments for function randomFixedString doesn't match: passed 2, should be 1: In scope SELECT randomFixedString(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:09:31.991655 [ 20379 ] {f794b57c-f702-43e2-9c2e-5caca8b5cd00} executeQuery: Code: 60. DB::Exception: Could not find table: rmt. (UNKNOWN_TABLE) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:50678) (comment: 01155_old_mutation_parts_to_do.sh) (in query: alter table rmt modify setting max_replicated_mutations_in_queue=1;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x000000000aafc574 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:127: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000291758a0 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x0000000029170711 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b382fc 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 9. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 13. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 14. asan_thread_start(void*) @ 0x000000000aa43059 15. ? @ 0x00007f35aab92ac3 16. ? @ 0x00007f35aac24850 2025.09.09 15:09:31.995593 [ 2747 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:09:31.999853 [ 20379 ] {f794b57c-f702-43e2-9c2e-5caca8b5cd00} TCPHandler: Code: 60. DB::Exception: Could not find table: rmt. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x000000000aafc574 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:127: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000291758a0 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x0000000029170711 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b382fc 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 9. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 13. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 14. asan_thread_start(void*) @ 0x000000000aa43059 15. ? @ 0x00007f35aab92ac3 16. ? @ 0x00007f35aac24850 2025.09.09 15:09:32.105872 [ 20345 ] {bcc23ee7-7c72-4eae-9314-88b64dd8d3c5} executeQuery: Code: 42. DB::Exception: Number of arguments for function randomStringUTF8 doesn't match: passed 2, should be 1: In scope SELECT randomStringUTF8(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT randomStringUTF8(NULL, NULL);) 2025.09.09 15:09:32.128486 [ 20345 ] {bcc23ee7-7c72-4eae-9314-88b64dd8d3c5} TCPHandler: Code: 42. DB::Exception: Number of arguments for function randomStringUTF8 doesn't match: passed 2, should be 1: In scope SELECT randomStringUTF8(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:09:32.279874 [ 2892 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:09:32.433465 [ 2878 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:09:32.495025 [ 20345 ] {47936ae9-bb41-49a8-8faf-0f6b4da2b1a5} executeQuery: Code: 36. DB::Exception: The function 'rank' can only be used as a window function, not as an aggregate function: While executing AggregatingTransform. (BAD_ARGUMENTS) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT rank(NULL, NULL);) 2025.09.09 15:09:32.498250 [ 20345 ] {47936ae9-bb41-49a8-8faf-0f6b4da2b1a5} TCPHandler: Code: 36. DB::Exception: The function 'rank' can only be used as a window function, not as an aggregate function: While executing AggregatingTransform. (BAD_ARGUMENTS) 2025.09.09 15:09:32.525771 [ 2849 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:09:32.672782 [ 20345 ] {01eabe21-df0b-4b08-80c7-361d12278b60} executeQuery: Code: 42. DB::Exception: Number of arguments for function readWKTLineString doesn't match: passed 2, should be 1: In scope SELECT readWKTLineString(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT readWKTLineString(NULL, NULL);) 2025.09.09 15:09:32.680103 [ 20345 ] {01eabe21-df0b-4b08-80c7-361d12278b60} TCPHandler: Code: 42. DB::Exception: Number of arguments for function readWKTLineString doesn't match: passed 2, should be 1: In scope SELECT readWKTLineString(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:09:32.769178 [ 20345 ] {bf647c4d-d242-4f24-99ee-713d9726974c} executeQuery: Code: 42. DB::Exception: Number of arguments for function readWKTMultiLineString doesn't match: passed 2, should be 1: In scope SELECT readWKTMultiLineString(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT readWKTMultiLineString(NULL, NULL);) 2025.09.09 15:09:32.779043 [ 20345 ] {bf647c4d-d242-4f24-99ee-713d9726974c} TCPHandler: Code: 42. DB::Exception: Number of arguments for function readWKTMultiLineString doesn't match: passed 2, should be 1: In scope SELECT readWKTMultiLineString(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:09:32.850320 [ 20345 ] {518cddd0-30cb-4355-b504-432f1f590cb0} executeQuery: Code: 42. DB::Exception: Number of arguments for function readWKTMultiPolygon doesn't match: passed 2, should be 1: In scope SELECT readWKTMultiPolygon(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT readWKTMultiPolygon(NULL, NULL);) 2025.09.09 15:09:32.859700 [ 20345 ] {518cddd0-30cb-4355-b504-432f1f590cb0} TCPHandler: Code: 42. DB::Exception: Number of arguments for function readWKTMultiPolygon doesn't match: passed 2, should be 1: In scope SELECT readWKTMultiPolygon(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:09:32.972690 [ 20345 ] {93e709fc-20f8-4d12-bdb4-5127d3fae018} executeQuery: Code: 42. DB::Exception: Number of arguments for function readWKTPoint doesn't match: passed 2, should be 1: In scope SELECT readWKTPoint(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT readWKTPoint(NULL, NULL);) 2025.09.09 15:09:32.987717 [ 20345 ] {93e709fc-20f8-4d12-bdb4-5127d3fae018} TCPHandler: Code: 42. DB::Exception: Number of arguments for function readWKTPoint doesn't match: passed 2, should be 1: In scope SELECT readWKTPoint(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:09:32.997195 [ 2890 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:09:33.037850 [ 20345 ] {3b51d3c8-06d6-4d98-ac7c-0858ff196c91} executeQuery: Code: 42. DB::Exception: Number of arguments for function readWKTPolygon doesn't match: passed 2, should be 1: In scope SELECT readWKTPolygon(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT readWKTPolygon(NULL, NULL);) 2025.09.09 15:09:33.042136 [ 20345 ] {3b51d3c8-06d6-4d98-ac7c-0858ff196c91} TCPHandler: Code: 42. DB::Exception: Number of arguments for function readWKTPolygon doesn't match: passed 2, should be 1: In scope SELECT readWKTPolygon(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:09:33.100708 [ 20345 ] {71aa0173-22f1-4163-ac79-257e89bd0594} executeQuery: Code: 42. DB::Exception: Number of arguments for function readWKTRing doesn't match: passed 2, should be 1: In scope SELECT readWKTRing(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT readWKTRing(NULL, NULL);) 2025.09.09 15:09:33.104462 [ 20345 ] {71aa0173-22f1-4163-ac79-257e89bd0594} TCPHandler: Code: 42. DB::Exception: Number of arguments for function readWKTRing doesn't match: passed 2, should be 1: In scope SELECT readWKTRing(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:09:33.245812 [ 20345 ] {0f04425b-97c9-43ff-a779-be93ae60e5c5} executeQuery: Code: 42. DB::Exception: Number of arguments for function regexpQuoteMeta doesn't match: passed 2, should be 1: In scope SELECT regexpQuoteMeta(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT regexpQuoteMeta(NULL, NULL);) 2025.09.09 15:09:33.248291 [ 20345 ] {0f04425b-97c9-43ff-a779-be93ae60e5c5} TCPHandler: Code: 42. DB::Exception: Number of arguments for function regexpQuoteMeta doesn't match: passed 2, should be 1: In scope SELECT regexpQuoteMeta(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:09:33.283469 [ 2937 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:09:33.527542 [ 3021 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:09:33.531097 [ 2958 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:09:33.999887 [ 3031 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:09:34.285777 [ 3063 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:09:34.530022 [ 3072 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:09:34.533610 [ 3077 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:09:34.605392 [ 20345 ] {c0f9c7d3-78c1-49cb-8644-9124287d0a9c} executeQuery: Code: 42. DB::Exception: Number of arguments for function reinterpretAsDate doesn't match: passed 2, should be 1: In scope SELECT reinterpretAsDate(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT reinterpretAsDate(NULL, NULL);) 2025.09.09 15:09:34.618341 [ 20345 ] {c0f9c7d3-78c1-49cb-8644-9124287d0a9c} TCPHandler: Code: 42. DB::Exception: Number of arguments for function reinterpretAsDate doesn't match: passed 2, should be 1: In scope SELECT reinterpretAsDate(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:09:34.698589 [ 20345 ] {f557285e-f37c-4b36-9534-6981c1ad3cdd} executeQuery: Code: 42. DB::Exception: Number of arguments for function reinterpretAsDateTime doesn't match: passed 2, should be 1: In scope SELECT reinterpretAsDateTime(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT reinterpretAsDateTime(NULL, NULL);) 2025.09.09 15:09:34.775074 [ 20345 ] {f557285e-f37c-4b36-9534-6981c1ad3cdd} TCPHandler: Code: 42. DB::Exception: Number of arguments for function reinterpretAsDateTime doesn't match: passed 2, should be 1: In scope SELECT reinterpretAsDateTime(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:09:34.877557 [ 20345 ] {a86424c6-994f-4f3f-9876-c6a47226fd40} executeQuery: Code: 42. DB::Exception: Number of arguments for function reinterpretAsFixedString doesn't match: passed 2, should be 1: In scope SELECT reinterpretAsFixedString(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT reinterpretAsFixedString(NULL, NULL);) 2025.09.09 15:09:34.891712 [ 20345 ] {a86424c6-994f-4f3f-9876-c6a47226fd40} TCPHandler: Code: 42. DB::Exception: Number of arguments for function reinterpretAsFixedString doesn't match: passed 2, should be 1: In scope SELECT reinterpretAsFixedString(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:09:35.058338 [ 20345 ] {c8cc2eab-279e-4bc5-922b-2b9caa9abf17} executeQuery: Code: 42. DB::Exception: Number of arguments for function reinterpretAsFloat32 doesn't match: passed 2, should be 1: In scope SELECT reinterpretAsFloat32(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT reinterpretAsFloat32(NULL, NULL);) 2025.09.09 15:09:35.059401 [ 3075 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:09:35.061824 [ 20345 ] {c8cc2eab-279e-4bc5-922b-2b9caa9abf17} TCPHandler: Code: 42. DB::Exception: Number of arguments for function reinterpretAsFloat32 doesn't match: passed 2, should be 1: In scope SELECT reinterpretAsFloat32(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:09:35.155275 [ 20345 ] {b35007a6-41e7-42ff-875e-9d2439786451} executeQuery: Code: 42. DB::Exception: Number of arguments for function reinterpretAsFloat64 doesn't match: passed 2, should be 1: In scope SELECT reinterpretAsFloat64(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT reinterpretAsFloat64(NULL, NULL);) 2025.09.09 15:09:35.165471 [ 20345 ] {b35007a6-41e7-42ff-875e-9d2439786451} TCPHandler: Code: 42. DB::Exception: Number of arguments for function reinterpretAsFloat64 doesn't match: passed 2, should be 1: In scope SELECT reinterpretAsFloat64(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:09:35.284829 [ 20345 ] {ce0e740d-24ec-42f5-a503-024484c9f8e7} executeQuery: Code: 42. DB::Exception: Number of arguments for function reinterpretAsInt128 doesn't match: passed 2, should be 1: In scope SELECT reinterpretAsInt128(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT reinterpretAsInt128(NULL, NULL);) 2025.09.09 15:09:35.288473 [ 3131 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:09:35.291339 [ 20345 ] {ce0e740d-24ec-42f5-a503-024484c9f8e7} TCPHandler: Code: 42. DB::Exception: Number of arguments for function reinterpretAsInt128 doesn't match: passed 2, should be 1: In scope SELECT reinterpretAsInt128(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:09:35.412538 [ 20345 ] {4ba0bd05-fda3-44bf-bd31-3764d6dfc8a2} executeQuery: Code: 42. DB::Exception: Number of arguments for function reinterpretAsInt16 doesn't match: passed 2, should be 1: In scope SELECT reinterpretAsInt16(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT reinterpretAsInt16(NULL, NULL);) 2025.09.09 15:09:35.424268 [ 20345 ] {4ba0bd05-fda3-44bf-bd31-3764d6dfc8a2} TCPHandler: Code: 42. DB::Exception: Number of arguments for function reinterpretAsInt16 doesn't match: passed 2, should be 1: In scope SELECT reinterpretAsInt16(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:09:35.532787 [ 3163 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:09:35.534379 [ 20345 ] {0c0ba410-a602-43cd-b180-3b3a77b52729} executeQuery: Code: 42. DB::Exception: Number of arguments for function reinterpretAsInt256 doesn't match: passed 2, should be 1: In scope SELECT reinterpretAsInt256(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT reinterpretAsInt256(NULL, NULL);) 2025.09.09 15:09:35.536663 [ 3144 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:09:35.632486 [ 20345 ] {0c0ba410-a602-43cd-b180-3b3a77b52729} TCPHandler: Code: 42. DB::Exception: Number of arguments for function reinterpretAsInt256 doesn't match: passed 2, should be 1: In scope SELECT reinterpretAsInt256(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:09:35.736538 [ 20345 ] {b39c4c43-412d-4584-b61e-2097b5b5e08f} executeQuery: Code: 42. DB::Exception: Number of arguments for function reinterpretAsInt32 doesn't match: passed 2, should be 1: In scope SELECT reinterpretAsInt32(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT reinterpretAsInt32(NULL, NULL);) 2025.09.09 15:09:35.758368 [ 20345 ] {b39c4c43-412d-4584-b61e-2097b5b5e08f} TCPHandler: Code: 42. DB::Exception: Number of arguments for function reinterpretAsInt32 doesn't match: passed 2, should be 1: In scope SELECT reinterpretAsInt32(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:09:35.931765 [ 3494 ] {} 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. ./contrib/llvm-project/libcxx/include/string:1499: _ZN12Coordination9ExceptionC2IRA41_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x000000002cb2daa6 3. ./src/Common/ZooKeeper/IKeeper.h:509: _ZN12Coordination9Exception11fromMessageIRA41_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEES0_NS_5ErrorEOS5_ @ 0x000000002e6d1195 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1660: Coordination::ZooKeeper::maybeInjectRecvFault() @ 0x000000002e6c134a 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:0: Coordination::ZooKeeper::receiveEvent() @ 0x000000002e6bf27c 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:0: Coordination::ZooKeeper::receiveThread() @ 0x000000002e6be17c 7. ./src/Common/ThreadPool.h:312: 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*) @ 0x000000002e6ceaa7 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 10. asan_thread_start(void*) @ 0x000000000aa43059 11. ? @ 0x00007f35aab92ac3 12. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:09:35.936655 [ 3128 ] {} test_3.part_log_profile_events_r2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.09.09 15:09:35.939600 [ 3130 ] {} test_3.part_header_r2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.09.09 15:09:35.940765 [ 3164 ] {} test_3.part_header_r1 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.09.09 15:09:35.943658 [ 3173 ] {} test_3.part_log_profile_events_r1 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.09.09 15:09:35.945994 [ 3184 ] {} test_3.test_03217_merge_replica_2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.09.09 15:09:35.947491 [ 3178 ] {} test_3.src (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.09.09 15:09:35.948816 [ 3167 ] {} test_3.test_03217_merge_replica_1 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.09.09 15:09:35.951216 [ 3198 ] {} test_15.primary_key (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.09.09 15:09:35.952676 [ 3180 ] {} test_1.order_by_all (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.09.09 15:09:35.953475 [ 3139 ] {} test_3.part_header_r2 (ReplicatedMergeTreeCleanupThread): void DB::ReplicatedMergeTreeCleanupThread::run(): Code: 999. Coordination::Exception: Coordination error: Connection loss, path /clickhouse/tables/00814_replicated_minimalistic_part_header_zookeeper_test_3/test_00814/part_header/s1/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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: Coordination::Exception::Exception(Coordination::Error, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x00000000264863d9 4. ./src/Common/ZooKeeper/IKeeper.h:501: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x00000000264847c3 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:601: zkutil::ZooKeeper::existsWatch(String const&, Coordination::Stat*, std::function) @ 0x000000002e5f1707 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002e5ebc63 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:203: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x000000002ca16d1a 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x000000002ca15340 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:50: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x000000002ca13666 10. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 12. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 15. asan_thread_start(void*) @ 0x000000000aa43059 16. ? @ 0x00007f35aab92ac3 17. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:09:35.963752 [ 3191 ] {} test_3.part_header_r1 (badd489f-7d85-4dd7-8882-42d31f43e543): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/00814_replicated_minimalistic_part_header_zookeeper_test_3/test_00814/part_header/s1/replicas/1r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:09:35.964547 [ 3174 ] {} test_3.part_header_r2 (ccbf4dd0-4073-493b-966a-233c0c02c225): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/00814_replicated_minimalistic_part_header_zookeeper_test_3/test_00814/part_header/s1/replicas/2r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:09:35.965511 [ 3171 ] {} test_15.primary_key (b9a7fafa-043d-4b0b-9528-df8e4980f529): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_15/test_00215/primary_key/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:09:35.966121 [ 3182 ] {} test_3.part_header_r1 (badd489f-7d85-4dd7-8882-42d31f43e543): 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. ./contrib/llvm-project/libcxx/include/string:1499: _ZN12Coordination9ExceptionC2IRA16_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x000000002e65bfe6 3. ./src/Common/ZooKeeper/IKeeper.h:0: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x000000002e6c2259 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1437: Coordination::ZooKeeper::list(String const&, Coordination::ListRequestType, std::function, std::shared_ptr>) @ 0x000000002e6caac6 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002e5e9637 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:299: zkutil::ZooKeeper::getChildrenImpl(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000002e5e8bfa 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:372: zkutil::ZooKeeper::tryGetChildrenWatch(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000002e5ea588 8. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:57: zkutil::ZooKeeper::getChildrenWatch(String const&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000002e5ea43b 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:914: DB::ReplicatedMergeTreeQueue::updateMutations(std::shared_ptr, std::shared_ptr>) @ 0x000000002ca8268c 10. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3622: DB::StorageReplicatedMergeTree::mutationsUpdatingTask() @ 0x000000002baf70bc 11. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 13. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 16. asan_thread_start(void*) @ 0x000000000aa43059 17. ? @ 0x00007f35aab92ac3 18. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:09:35.966432 [ 3161 ] {} test_3.part_header_r2 (ccbf4dd0-4073-493b-966a-233c0c02c225): 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. ./contrib/llvm-project/libcxx/include/string:1499: _ZN12Coordination9ExceptionC2IRA16_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x000000002e65bfe6 3. ./src/Common/ZooKeeper/IKeeper.h:0: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x000000002e6c2259 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1437: Coordination::ZooKeeper::list(String const&, Coordination::ListRequestType, std::function, std::shared_ptr>) @ 0x000000002e6caac6 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002e5e9637 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:299: zkutil::ZooKeeper::getChildrenImpl(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000002e5e8bfa 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:372: zkutil::ZooKeeper::tryGetChildrenWatch(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000002e5ea588 8. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:57: zkutil::ZooKeeper::getChildrenWatch(String const&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000002e5ea43b 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:914: DB::ReplicatedMergeTreeQueue::updateMutations(std::shared_ptr, std::shared_ptr>) @ 0x000000002ca8268c 10. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3622: DB::StorageReplicatedMergeTree::mutationsUpdatingTask() @ 0x000000002baf70bc 11. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 13. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 16. asan_thread_start(void*) @ 0x000000000aa43059 17. ? @ 0x00007f35aab92ac3 18. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:09:35.968240 [ 3183 ] {} test_3.part_log_profile_events_r1 (d2579ae8-cbf6-4e32-8d68-3aedfa4d5aba): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_3/test_02378/part_log_profile_events/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:09:35.968381 [ 3192 ] {} test_15.primary_key (b9a7fafa-043d-4b0b-9528-df8e4980f529): 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. ./contrib/llvm-project/libcxx/include/string:1499: _ZN12Coordination9ExceptionC2IRA16_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x000000002e65bfe6 3. ./src/Common/ZooKeeper/IKeeper.h:0: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x000000002e6c2259 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1437: Coordination::ZooKeeper::list(String const&, Coordination::ListRequestType, std::function, std::shared_ptr>) @ 0x000000002e6caac6 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002e5e9637 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:299: zkutil::ZooKeeper::getChildrenImpl(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000002e5e8bfa 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:372: zkutil::ZooKeeper::tryGetChildrenWatch(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000002e5ea588 8. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:57: zkutil::ZooKeeper::getChildrenWatch(String const&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000002e5ea43b 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:914: DB::ReplicatedMergeTreeQueue::updateMutations(std::shared_ptr, std::shared_ptr>) @ 0x000000002ca8268c 10. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3622: DB::StorageReplicatedMergeTree::mutationsUpdatingTask() @ 0x000000002baf70bc 11. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 13. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 16. asan_thread_start(void*) @ 0x000000000aa43059 17. ? @ 0x00007f35aab92ac3 18. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:09:35.968447 [ 3195 ] {} test_3.src (a9587bc6-09b3-4b5a-81da-b7c2446903c9): 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. ./contrib/llvm-project/libcxx/include/string:1499: _ZN12Coordination9ExceptionC2IRA16_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x000000002e65bfe6 3. ./src/Common/ZooKeeper/IKeeper.h:0: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x000000002e6c2259 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1437: Coordination::ZooKeeper::list(String const&, Coordination::ListRequestType, std::function, std::shared_ptr>) @ 0x000000002e6caac6 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002e5e9637 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:299: zkutil::ZooKeeper::getChildrenImpl(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000002e5e8bfa 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:372: zkutil::ZooKeeper::tryGetChildrenWatch(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000002e5ea588 8. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:57: zkutil::ZooKeeper::getChildrenWatch(String const&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000002e5ea43b 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:914: DB::ReplicatedMergeTreeQueue::updateMutations(std::shared_ptr, std::shared_ptr>) @ 0x000000002ca8268c 10. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3622: DB::StorageReplicatedMergeTree::mutationsUpdatingTask() @ 0x000000002baf70bc 11. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 13. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 16. asan_thread_start(void*) @ 0x000000000aa43059 17. ? @ 0x00007f35aab92ac3 18. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:09:35.968189 [ 3139 ] {} test_3.part_header_r2 (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. ./contrib/llvm-project/libcxx/include/string:1499: _ZN12Coordination9ExceptionC2IRA16_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x000000002e65bfe6 3. ./src/Common/ZooKeeper/IKeeper.h:0: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x000000002e6c2259 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1365: Coordination::ZooKeeper::exists(String const&, std::function, std::shared_ptr>) @ 0x000000002e6c8872 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002e5f1235 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002e5f076a 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:598: zkutil::ZooKeeper::existsWatch(String const&, Coordination::Stat*, std::function) @ 0x000000002e5f16a2 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002e5ebc63 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:203: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x000000002ca16d1a 10. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x000000002ca15340 11. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:50: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x000000002ca13666 12. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 14. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:09:35.968603 [ 3214 ] {} test_3.part_log_profile_events_r2 (c6c145b3-8dfa-456b-a838-7d32ade90493): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_3/test_02378/part_log_profile_events/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:09:35.970082 [ 3221 ] {} test_3.test_03217_merge_replica_1 (558cd764-871b-4cdb-bd3d-87bfe9d01bf6): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_3/test_03217_merge_replica/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:09:35.970442 [ 3196 ] {} test_3.test_03217_merge_replica_2 (84f84548-349b-4925-ab55-cc31c8bb600b): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_3/test_03217_merge_replica/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:09:35.970844 [ 3161 ] {} test_3.part_log_profile_events_r1 (d2579ae8-cbf6-4e32-8d68-3aedfa4d5aba): 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. ./contrib/llvm-project/libcxx/include/string:1499: _ZN12Coordination9ExceptionC2IRA16_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x000000002e65bfe6 3. ./src/Common/ZooKeeper/IKeeper.h:0: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x000000002e6c2259 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1437: Coordination::ZooKeeper::list(String const&, Coordination::ListRequestType, std::function, std::shared_ptr>) @ 0x000000002e6caac6 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002e5e9637 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:299: zkutil::ZooKeeper::getChildrenImpl(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000002e5e8bfa 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:372: zkutil::ZooKeeper::tryGetChildrenWatch(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000002e5ea588 8. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:57: zkutil::ZooKeeper::getChildrenWatch(String const&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000002e5ea43b 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:914: DB::ReplicatedMergeTreeQueue::updateMutations(std::shared_ptr, std::shared_ptr>) @ 0x000000002ca8268c 10. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3622: DB::StorageReplicatedMergeTree::mutationsUpdatingTask() @ 0x000000002baf70bc 11. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 13. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 16. asan_thread_start(void*) @ 0x000000000aa43059 17. ? @ 0x00007f35aab92ac3 18. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:09:35.970936 [ 3193 ] {} test_3.part_log_profile_events_r2 (c6c145b3-8dfa-456b-a838-7d32ade90493): 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. ./contrib/llvm-project/libcxx/include/string:1499: _ZN12Coordination9ExceptionC2IRA16_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x000000002e65bfe6 3. ./src/Common/ZooKeeper/IKeeper.h:0: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x000000002e6c2259 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1437: Coordination::ZooKeeper::list(String const&, Coordination::ListRequestType, std::function, std::shared_ptr>) @ 0x000000002e6caac6 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002e5e9637 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:299: zkutil::ZooKeeper::getChildrenImpl(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000002e5e8bfa 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:372: zkutil::ZooKeeper::tryGetChildrenWatch(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000002e5ea588 8. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:57: zkutil::ZooKeeper::getChildrenWatch(String const&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000002e5ea43b 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:914: DB::ReplicatedMergeTreeQueue::updateMutations(std::shared_ptr, std::shared_ptr>) @ 0x000000002ca8268c 10. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3622: DB::StorageReplicatedMergeTree::mutationsUpdatingTask() @ 0x000000002baf70bc 11. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 13. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 16. asan_thread_start(void*) @ 0x000000000aa43059 17. ? @ 0x00007f35aab92ac3 18. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:09:35.971691 [ 20345 ] {829c2966-d69d-4ec7-9652-562476f81a33} executeQuery: Code: 42. DB::Exception: Number of arguments for function reinterpretAsInt64 doesn't match: passed 2, should be 1: In scope SELECT reinterpretAsInt64(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT reinterpretAsInt64(NULL, NULL);) 2025.09.09 15:09:35.973895 [ 3171 ] {} test_1.order_by_all (a211317f-15a5-4e41-9466-f0e3dc49fa7b): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_1/test_03210/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:09:35.974468 [ 3177 ] {} test_3.src (a9587bc6-09b3-4b5a-81da-b7c2446903c9): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_3/03008_deduplication_remote_insert_select/src/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:09:35.975220 [ 3139 ] {} test_3.test_03217_merge_replica_1 (558cd764-871b-4cdb-bd3d-87bfe9d01bf6): 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. ./contrib/llvm-project/libcxx/include/string:1499: _ZN12Coordination9ExceptionC2IRA16_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x000000002e65bfe6 3. ./src/Common/ZooKeeper/IKeeper.h:0: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x000000002e6c2259 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1437: Coordination::ZooKeeper::list(String const&, Coordination::ListRequestType, std::function, std::shared_ptr>) @ 0x000000002e6caac6 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002e5e9637 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:299: zkutil::ZooKeeper::getChildrenImpl(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000002e5e8bfa 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:372: zkutil::ZooKeeper::tryGetChildrenWatch(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000002e5ea588 8. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:57: zkutil::ZooKeeper::getChildrenWatch(String const&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000002e5ea43b 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:914: DB::ReplicatedMergeTreeQueue::updateMutations(std::shared_ptr, std::shared_ptr>) @ 0x000000002ca8268c 10. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3622: DB::StorageReplicatedMergeTree::mutationsUpdatingTask() @ 0x000000002baf70bc 11. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 13. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 16. asan_thread_start(void*) @ 0x000000000aa43059 17. ? @ 0x00007f35aab92ac3 18. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:09:35.975504 [ 3191 ] {} test_3.test_03217_merge_replica_2 (84f84548-349b-4925-ab55-cc31c8bb600b): 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. ./contrib/llvm-project/libcxx/include/string:1499: _ZN12Coordination9ExceptionC2IRA16_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x000000002e65bfe6 3. ./src/Common/ZooKeeper/IKeeper.h:0: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x000000002e6c2259 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1437: Coordination::ZooKeeper::list(String const&, Coordination::ListRequestType, std::function, std::shared_ptr>) @ 0x000000002e6caac6 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002e5e9637 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:299: zkutil::ZooKeeper::getChildrenImpl(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000002e5e8bfa 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:372: zkutil::ZooKeeper::tryGetChildrenWatch(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000002e5ea588 8. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:57: zkutil::ZooKeeper::getChildrenWatch(String const&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000002e5ea43b 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:914: DB::ReplicatedMergeTreeQueue::updateMutations(std::shared_ptr, std::shared_ptr>) @ 0x000000002ca8268c 10. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3622: DB::StorageReplicatedMergeTree::mutationsUpdatingTask() @ 0x000000002baf70bc 11. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 13. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 16. asan_thread_start(void*) @ 0x000000000aa43059 17. ? @ 0x00007f35aab92ac3 18. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:09:35.975637 [ 3189 ] {} test_1.order_by_all (a211317f-15a5-4e41-9466-f0e3dc49fa7b): 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. ./contrib/llvm-project/libcxx/include/string:1499: _ZN12Coordination9ExceptionC2IRA16_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x000000002e65bfe6 3. ./src/Common/ZooKeeper/IKeeper.h:0: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x000000002e6c2259 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1437: Coordination::ZooKeeper::list(String const&, Coordination::ListRequestType, std::function, std::shared_ptr>) @ 0x000000002e6caac6 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002e5e9637 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:299: zkutil::ZooKeeper::getChildrenImpl(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000002e5e8bfa 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:372: zkutil::ZooKeeper::tryGetChildrenWatch(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000002e5ea588 8. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:57: zkutil::ZooKeeper::getChildrenWatch(String const&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000002e5ea43b 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:914: DB::ReplicatedMergeTreeQueue::updateMutations(std::shared_ptr, std::shared_ptr>) @ 0x000000002ca8268c 10. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3622: DB::StorageReplicatedMergeTree::mutationsUpdatingTask() @ 0x000000002baf70bc 11. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 13. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 16. asan_thread_start(void*) @ 0x000000000aa43059 17. ? @ 0x00007f35aab92ac3 18. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:09:35.977549 [ 20345 ] {829c2966-d69d-4ec7-9652-562476f81a33} TCPHandler: Code: 42. DB::Exception: Number of arguments for function reinterpretAsInt64 doesn't match: passed 2, should be 1: In scope SELECT reinterpretAsInt64(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:09:36.061923 [ 3203 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:09:36.096760 [ 20345 ] {ce409334-e2af-4c8b-a293-72cb7c0c5461} executeQuery: Code: 42. DB::Exception: Number of arguments for function reinterpretAsInt8 doesn't match: passed 2, should be 1: In scope SELECT reinterpretAsInt8(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT reinterpretAsInt8(NULL, NULL);) 2025.09.09 15:09:36.108699 [ 20345 ] {ce409334-e2af-4c8b-a293-72cb7c0c5461} TCPHandler: Code: 42. DB::Exception: Number of arguments for function reinterpretAsInt8 doesn't match: passed 2, should be 1: In scope SELECT reinterpretAsInt8(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:09:36.169805 [ 3153 ] {} test_3.part_header_r1 (ReplicatedMergeTreeCleanupThread): void DB::ReplicatedMergeTreeCleanupThread::run(): Code: 999. Coordination::Exception: Coordination error: Connection loss, path /clickhouse/tables/00814_replicated_minimalistic_part_header_zookeeper_test_3/test_00814/part_header/s1/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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: Coordination::Exception::Exception(Coordination::Error, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x00000000264863d9 4. ./src/Common/ZooKeeper/IKeeper.h:501: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x00000000264847c3 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:373: zkutil::ZooKeeper::tryGetChildrenWatch(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000002e5ea628 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:346: zkutil::ZooKeeper::tryGetChildren(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr const&, Coordination::ListRequestType) @ 0x000000002e5e9d09 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:514: DB::ReplicatedMergeTreeCleanupThread::getBlocksSortedByTime(String const&, zkutil::ZooKeeper&, std::vector>&, std::map, std::less, std::allocator>>>&) @ 0x000000002ca25d67 8. ./contrib/llvm-project/libcxx/include/vector:553: DB::ReplicatedMergeTreeCleanupThread::clearOldBlocks(String const&, unsigned long, unsigned long, std::map, std::less, std::allocator>>>&) @ 0x000000002ca1d797 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:165: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x000000002ca1548f 10. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:50: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x000000002ca13666 11. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 13. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 16. asan_thread_start(void*) @ 0x000000000aa43059 17. ? @ 0x00007f35aab92ac3 18. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:09:36.182343 [ 3194 ] {} test_3.part_header_r1 (ReplicatedMergeTreeCleanupThread): void DB::ReplicatedMergeTreeCleanupThread::run(): Code: 999. Coordination::Exception: Session expired. (KEEPER_EXCEPTION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. ./contrib/llvm-project/libcxx/include/string:1499: _ZN12Coordination9ExceptionC2IRA16_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x000000002e65bfe6 3. ./src/Common/ZooKeeper/IKeeper.h:0: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x000000002e6c2259 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1365: Coordination::ZooKeeper::exists(String const&, std::function, std::shared_ptr>) @ 0x000000002e6c8872 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002e5f1235 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002e5f076a 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:598: zkutil::ZooKeeper::existsWatch(String const&, Coordination::Stat*, std::function) @ 0x000000002e5f16a2 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002e5ebc63 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:203: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x000000002ca16d1a 10. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x000000002ca15340 11. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:50: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x000000002ca13666 12. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 14. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:09:36.198217 [ 20345 ] {9e515d2c-a851-46dc-b5cb-a84b6b98197a} executeQuery: Code: 42. DB::Exception: Number of arguments for function reinterpretAsString doesn't match: passed 2, should be 1: In scope SELECT reinterpretAsString(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT reinterpretAsString(NULL, NULL);) 2025.09.09 15:09:36.202202 [ 20345 ] {9e515d2c-a851-46dc-b5cb-a84b6b98197a} TCPHandler: Code: 42. DB::Exception: Number of arguments for function reinterpretAsString doesn't match: passed 2, should be 1: In scope SELECT reinterpretAsString(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:09:36.291447 [ 3201 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:09:36.335547 [ 20345 ] {f25eadfd-810b-41f5-9195-b06097f0c33a} executeQuery: Code: 42. DB::Exception: Number of arguments for function reinterpretAsUInt128 doesn't match: passed 2, should be 1: In scope SELECT reinterpretAsUInt128(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT reinterpretAsUInt128(NULL, NULL);) 2025.09.09 15:09:36.343865 [ 20345 ] {f25eadfd-810b-41f5-9195-b06097f0c33a} TCPHandler: Code: 42. DB::Exception: Number of arguments for function reinterpretAsUInt128 doesn't match: passed 2, should be 1: In scope SELECT reinterpretAsUInt128(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:09:36.437497 [ 20345 ] {723270c4-f955-481a-a14f-509183cb280a} executeQuery: Code: 42. DB::Exception: Number of arguments for function reinterpretAsUInt16 doesn't match: passed 2, should be 1: In scope SELECT reinterpretAsUInt16(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT reinterpretAsUInt16(NULL, NULL);) 2025.09.09 15:09:36.447028 [ 20345 ] {723270c4-f955-481a-a14f-509183cb280a} TCPHandler: Code: 42. DB::Exception: Number of arguments for function reinterpretAsUInt16 doesn't match: passed 2, should be 1: In scope SELECT reinterpretAsUInt16(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:09:36.535929 [ 3237 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:09:36.540862 [ 20345 ] {632229da-ce9e-4212-b77b-1ddc79387db0} executeQuery: Code: 42. DB::Exception: Number of arguments for function reinterpretAsUInt256 doesn't match: passed 2, should be 1: In scope SELECT reinterpretAsUInt256(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT reinterpretAsUInt256(NULL, NULL);) 2025.09.09 15:09:36.592857 [ 20345 ] {632229da-ce9e-4212-b77b-1ddc79387db0} TCPHandler: Code: 42. DB::Exception: Number of arguments for function reinterpretAsUInt256 doesn't match: passed 2, should be 1: In scope SELECT reinterpretAsUInt256(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:09:36.628349 [ 3208 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:09:36.686264 [ 20345 ] {82e00aff-8c5a-487c-9646-44a68908c02b} executeQuery: Code: 42. DB::Exception: Number of arguments for function reinterpretAsUInt32 doesn't match: passed 2, should be 1: In scope SELECT reinterpretAsUInt32(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT reinterpretAsUInt32(NULL, NULL);) 2025.09.09 15:09:36.767363 [ 20345 ] {82e00aff-8c5a-487c-9646-44a68908c02b} TCPHandler: Code: 42. DB::Exception: Number of arguments for function reinterpretAsUInt32 doesn't match: passed 2, should be 1: In scope SELECT reinterpretAsUInt32(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:09:36.868683 [ 20345 ] {445fa869-7f7b-4b87-b8e2-21b51a29598d} executeQuery: Code: 42. DB::Exception: Number of arguments for function reinterpretAsUInt64 doesn't match: passed 2, should be 1: In scope SELECT reinterpretAsUInt64(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT reinterpretAsUInt64(NULL, NULL);) 2025.09.09 15:09:36.874279 [ 20345 ] {445fa869-7f7b-4b87-b8e2-21b51a29598d} TCPHandler: Code: 42. DB::Exception: Number of arguments for function reinterpretAsUInt64 doesn't match: passed 2, should be 1: In scope SELECT reinterpretAsUInt64(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:09:36.952398 [ 20345 ] {c4b25245-eb74-4831-a8cb-ae48443c049e} executeQuery: Code: 42. DB::Exception: Number of arguments for function reinterpretAsUInt8 doesn't match: passed 2, should be 1: In scope SELECT reinterpretAsUInt8(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT reinterpretAsUInt8(NULL, NULL);) 2025.09.09 15:09:36.960953 [ 20345 ] {c4b25245-eb74-4831-a8cb-ae48443c049e} TCPHandler: Code: 42. DB::Exception: Number of arguments for function reinterpretAsUInt8 doesn't match: passed 2, should be 1: In scope SELECT reinterpretAsUInt8(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:09:37.092296 [ 20345 ] {3af5b3ae-8fc3-48f4-b2f3-0689ae65b893} executeQuery: Code: 42. DB::Exception: Number of arguments for function reinterpretAsUUID doesn't match: passed 2, should be 1: In scope SELECT reinterpretAsUUID(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT reinterpretAsUUID(NULL, NULL);) 2025.09.09 15:09:37.114867 [ 20345 ] {3af5b3ae-8fc3-48f4-b2f3-0689ae65b893} TCPHandler: Code: 42. DB::Exception: Number of arguments for function reinterpretAsUUID doesn't match: passed 2, should be 1: In scope SELECT reinterpretAsUUID(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:09:37.132502 [ 2769 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:09:37.293800 [ 2797 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:09:37.444452 [ 20345 ] {1ba9812f-ec58-472d-bf1a-51965a98d076} executeQuery: Code: 42. DB::Exception: Number of arguments for function replaceAll doesn't match: passed 2, should be 3: In scope SELECT replace(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT replace(NULL, NULL);) 2025.09.09 15:09:37.453971 [ 20345 ] {1ba9812f-ec58-472d-bf1a-51965a98d076} TCPHandler: Code: 42. DB::Exception: Number of arguments for function replaceAll doesn't match: passed 2, should be 3: In scope SELECT replace(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:09:37.553357 [ 2820 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:09:37.606083 [ 20345 ] {79577aa0-a95a-4a38-8b8a-d1f4ea3629c1} executeQuery: Code: 42. DB::Exception: Number of arguments for function replaceAll doesn't match: passed 2, should be 3: In scope SELECT replaceAll(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT replaceAll(NULL, NULL);) 2025.09.09 15:09:37.612305 [ 20345 ] {79577aa0-a95a-4a38-8b8a-d1f4ea3629c1} TCPHandler: Code: 42. DB::Exception: Number of arguments for function replaceAll doesn't match: passed 2, should be 3: In scope SELECT replaceAll(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:09:37.640418 [ 2799 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:09:37.751398 [ 20345 ] {728ae955-0f43-4de8-8798-63530890cc80} executeQuery: Code: 42. DB::Exception: Number of arguments for function replaceOne doesn't match: passed 2, should be 3: In scope SELECT replaceOne(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT replaceOne(NULL, NULL);) 2025.09.09 15:09:38.045204 [ 20345 ] {728ae955-0f43-4de8-8798-63530890cc80} TCPHandler: Code: 42. DB::Exception: Number of arguments for function replaceOne doesn't match: passed 2, should be 3: In scope SELECT replaceOne(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:09:38.126317 [ 20345 ] {651af802-3db5-4d35-b809-5e49093fba27} executeQuery: Code: 42. DB::Exception: Number of arguments for function replaceRegexpAll doesn't match: passed 2, should be 3: In scope SELECT replaceRegexpAll(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT replaceRegexpAll(NULL, NULL);) 2025.09.09 15:09:38.141854 [ 2845 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:09:38.151826 [ 20345 ] {651af802-3db5-4d35-b809-5e49093fba27} TCPHandler: Code: 42. DB::Exception: Number of arguments for function replaceRegexpAll doesn't match: passed 2, should be 3: In scope SELECT replaceRegexpAll(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:09:38.289582 [ 20345 ] {98116e5c-655d-4dd8-a589-abf23219efd7} executeQuery: Code: 42. DB::Exception: Number of arguments for function replaceRegexpOne doesn't match: passed 2, should be 3: In scope SELECT replaceRegexpOne(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT replaceRegexpOne(NULL, NULL);) 2025.09.09 15:09:38.298466 [ 2876 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:09:38.321116 [ 20345 ] {98116e5c-655d-4dd8-a589-abf23219efd7} TCPHandler: Code: 42. DB::Exception: Number of arguments for function replaceRegexpOne doesn't match: passed 2, should be 3: In scope SELECT replaceRegexpOne(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:09:38.436299 [ 20345 ] {884f9455-da13-4bd7-a967-02b0bd7d79f3} executeQuery: Code: 43. DB::Exception: Argument 2 for function replicate must be array.: In scope SELECT replicate(NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT replicate(NULL, NULL);) 2025.09.09 15:09:38.443805 [ 20345 ] {884f9455-da13-4bd7-a967-02b0bd7d79f3} TCPHandler: Code: 43. DB::Exception: Argument 2 for function replicate must be array.: In scope SELECT replicate(NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.09.09 15:09:38.562054 [ 2917 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:09:38.643802 [ 2836 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:09:38.791026 [ 20345 ] {87166209-98a1-4391-8d29-99ebf4d6cf96} executeQuery: Code: 42. DB::Exception: Number of arguments for function reverse doesn't match: passed 2, should be 1: In scope SELECT reverse(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT reverse(NULL, NULL);) 2025.09.09 15:09:38.799722 [ 20345 ] {87166209-98a1-4391-8d29-99ebf4d6cf96} TCPHandler: Code: 42. DB::Exception: Number of arguments for function reverse doesn't match: passed 2, should be 1: In scope SELECT reverse(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:09:38.898172 [ 20345 ] {3ebffddd-41a8-4825-b995-8af30134be36} executeQuery: Code: 42. DB::Exception: Number of arguments for function reverseUTF8 doesn't match: passed 2, should be 1: In scope SELECT reverseUTF8(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT reverseUTF8(NULL, NULL);) 2025.09.09 15:09:38.915372 [ 20345 ] {3ebffddd-41a8-4825-b995-8af30134be36} TCPHandler: Code: 42. DB::Exception: Number of arguments for function reverseUTF8 doesn't match: passed 2, should be 1: In scope SELECT reverseUTF8(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:09:38.986892 [ 20345 ] {523d664c-644a-4da2-9d74-f27a19861a7f} executeQuery: Code: 42. DB::Exception: Number of arguments for function revision doesn't match: passed 2, should be 0: In scope SELECT revision(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT revision(NULL, NULL);) 2025.09.09 15:09:38.992981 [ 20345 ] {523d664c-644a-4da2-9d74-f27a19861a7f} TCPHandler: Code: 42. DB::Exception: Number of arguments for function revision doesn't match: passed 2, should be 0: In scope SELECT revision(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:09:39.081360 [ 20380 ] {4e2bb4ec-ab17-4e5a-a964-e61bd7e71f48} executeQuery: Code: 60. DB::Exception: Table test_15.rmt does not exist. (UNKNOWN_TABLE) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:39310) (comment: 01155_old_mutation_parts_to_do.sh) (in query: system sync replica rmt;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa91e9a 4. ./build_docker/./src/Databases/IDatabase.cpp:37: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000027dd1ade 5. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000286af00b 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000286bb117 7. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:1126: DB::InterpreterSystemQuery::syncReplica(DB::ASTSystemQuery&) @ 0x0000000029bad3ec 8. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:684: DB::InterpreterSystemQuery::execute() @ 0x0000000029b9adf7 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b382fc 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 15:09:39.089544 [ 20380 ] {4e2bb4ec-ab17-4e5a-a964-e61bd7e71f48} TCPHandler: Code: 60. DB::Exception: Table test_15.rmt 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa91e9a 4. ./build_docker/./src/Databases/IDatabase.cpp:37: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000027dd1ade 5. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000286af00b 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000286bb117 7. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:1126: DB::InterpreterSystemQuery::syncReplica(DB::ASTSystemQuery&) @ 0x0000000029bad3ec 8. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:684: DB::InterpreterSystemQuery::execute() @ 0x0000000029b9adf7 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b382fc 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 15:09:39.143831 [ 2890 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:09:39.301351 [ 2941 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:09:39.376513 [ 20345 ] {4f104c02-c3fd-448d-819b-0e07f31e8264} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=790, jobs=741). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT rightPadUTF8(NULL, NULL);) 2025.09.09 15:09:39.381776 [ 20345 ] {4f104c02-c3fd-448d-819b-0e07f31e8264} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=790, jobs=741). (CANNOT_SCHEDULE_TASK) 2025.09.09 15:09:39.587846 [ 2921 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:09:39.646106 [ 2976 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:09:39.691855 [ 20345 ] {f9f81153-0e14-4281-bd09-c611b2d96df6} executeQuery: Code: 42. DB::Exception: Number of arguments for function roundAge doesn't match: passed 2, should be 1: In scope SELECT roundAge(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT roundAge(NULL, NULL);) 2025.09.09 15:09:39.697761 [ 20345 ] {f9f81153-0e14-4281-bd09-c611b2d96df6} TCPHandler: Code: 42. DB::Exception: Number of arguments for function roundAge doesn't match: passed 2, should be 1: In scope SELECT roundAge(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:09:39.919599 [ 20345 ] {b930d9ab-1d37-4411-a67c-83a78d0efa9f} executeQuery: Code: 42. DB::Exception: Number of arguments for function roundDuration doesn't match: passed 2, should be 1: In scope SELECT roundDuration(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT roundDuration(NULL, NULL);) 2025.09.09 15:09:39.925331 [ 20345 ] {b930d9ab-1d37-4411-a67c-83a78d0efa9f} TCPHandler: Code: 42. DB::Exception: Number of arguments for function roundDuration doesn't match: passed 2, should be 1: In scope SELECT roundDuration(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:09:40.009748 [ 20345 ] {9626dc73-3e22-44ed-a7c5-2498341a69ec} executeQuery: Code: 42. DB::Exception: Number of arguments for function roundToExp2 doesn't match: passed 2, should be 1: In scope SELECT roundToExp2(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT roundToExp2(NULL, NULL);) 2025.09.09 15:09:40.013444 [ 20345 ] {9626dc73-3e22-44ed-a7c5-2498341a69ec} TCPHandler: Code: 42. DB::Exception: Number of arguments for function roundToExp2 doesn't match: passed 2, should be 1: In scope SELECT roundToExp2(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:09:40.122936 [ 20345 ] {6ad68c61-a0a4-4f1b-a26a-28634b027cbe} executeQuery: Code: 42. DB::Exception: Number of arguments for function rowNumberInAllBlocks doesn't match: passed 2, should be 0: In scope SELECT rowNumberInAllBlocks(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT rowNumberInAllBlocks(NULL, NULL);) 2025.09.09 15:09:40.126938 [ 20345 ] {6ad68c61-a0a4-4f1b-a26a-28634b027cbe} TCPHandler: Code: 42. DB::Exception: Number of arguments for function rowNumberInAllBlocks doesn't match: passed 2, should be 0: In scope SELECT rowNumberInAllBlocks(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:09:40.145648 [ 2967 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:09:40.181259 [ 20345 ] {d6d36d85-8aa2-4093-a55b-54c3c15c9808} executeQuery: Code: 42. DB::Exception: Number of arguments for function rowNumberInBlock doesn't match: passed 2, should be 0: In scope SELECT rowNumberInBlock(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT rowNumberInBlock(NULL, NULL);) 2025.09.09 15:09:40.185351 [ 20345 ] {d6d36d85-8aa2-4093-a55b-54c3c15c9808} TCPHandler: Code: 42. DB::Exception: Number of arguments for function rowNumberInBlock doesn't match: passed 2, should be 0: In scope SELECT rowNumberInBlock(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:09:40.304612 [ 2999 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:09:40.332787 [ 20345 ] {0b4ac0e0-48c7-4aa7-89a5-ddc31cae3b7e} executeQuery: Code: 36. DB::Exception: The function 'row_number' can only be used as a window function, not as an aggregate function: While executing AggregatingTransform. (BAD_ARGUMENTS) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT row_number(NULL, NULL);) 2025.09.09 15:09:40.349456 [ 20345 ] {0b4ac0e0-48c7-4aa7-89a5-ddc31cae3b7e} TCPHandler: Code: 36. DB::Exception: The function 'row_number' can only be used as a window function, not as an aggregate function: While executing AggregatingTransform. (BAD_ARGUMENTS) 2025.09.09 15:09:40.591938 [ 3057 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:09:40.648423 [ 3038 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:09:40.666023 [ 20345 ] {83006aaa-265b-40e9-bcc4-ec608eb991a6} executeQuery: Code: 721. DB::Exception: Function runningAccumulate is deprecated since its usage is error-prone (see docs).Please use proper window function or set `allow_deprecated_error_prone_window_functions` setting to enable it. (DEPRECATED_FUNCTION) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT runningAccumulate(NULL, NULL);) 2025.09.09 15:09:40.670559 [ 20345 ] {83006aaa-265b-40e9-bcc4-ec608eb991a6} TCPHandler: Code: 721. DB::Exception: Function runningAccumulate is deprecated since its usage is error-prone (see docs).Please use proper window function or set `allow_deprecated_error_prone_window_functions` setting to enable it. (DEPRECATED_FUNCTION) 2025.09.09 15:09:40.726134 [ 20345 ] {59b9633a-d206-4846-bbd1-43eba46dbe52} executeQuery: Code: 43. DB::Exception: Arguments for function runningConcurrency must be Date, DateTime, or DateTime64.: In scope SELECT runningConcurrency(NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT runningConcurrency(NULL, NULL);) 2025.09.09 15:09:40.729660 [ 20345 ] {59b9633a-d206-4846-bbd1-43eba46dbe52} TCPHandler: Code: 43. DB::Exception: Arguments for function runningConcurrency must be Date, DateTime, or DateTime64.: In scope SELECT runningConcurrency(NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.09.09 15:09:40.780940 [ 20345 ] {e83d49df-84da-48ab-b933-b12bd737e0f7} executeQuery: Code: 721. DB::Exception: Function runningDifference is deprecated since its usage is error-prone (see docs).Please use proper window function or set `allow_deprecated_error_prone_window_functions` setting to enable it. (DEPRECATED_FUNCTION) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT runningDifference(NULL, NULL);) 2025.09.09 15:09:40.785567 [ 20345 ] {e83d49df-84da-48ab-b933-b12bd737e0f7} TCPHandler: Code: 721. DB::Exception: Function runningDifference is deprecated since its usage is error-prone (see docs).Please use proper window function or set `allow_deprecated_error_prone_window_functions` setting to enable it. (DEPRECATED_FUNCTION) 2025.09.09 15:09:40.873333 [ 3722 ] {c745a417-7f4d-4ed6-b552-b4133335dbe1} executeQuery: Code: 62. DB::Exception: Cannot TRUNCATE dictionary. (SYNTAX_ERROR) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:39344) (comment: 02504_regexp_dictionary_yaml_source.sh) (in query: drop dictionary if exists regexp_dict4;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aac868e 4. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:262: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x00000000291f1adc 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x00000000291ed665 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x00000000291ebd68 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x00000000291eb7ed 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b382fc 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 11. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 15. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 16. asan_thread_start(void*) @ 0x000000000aa43059 17. ? @ 0x00007f35aab92ac3 18. ? @ 0x00007f35aac24850 2025.09.09 15:09:40.879576 [ 3722 ] {c745a417-7f4d-4ed6-b552-b4133335dbe1} 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aac868e 4. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:262: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x00000000291f1adc 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x00000000291ed665 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x00000000291ebd68 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x00000000291eb7ed 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b382fc 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 11. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 15. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 16. asan_thread_start(void*) @ 0x000000000aa43059 17. ? @ 0x00007f35aab92ac3 18. ? @ 0x00007f35aac24850 2025.09.09 15:09:40.879992 [ 20345 ] {746bb343-4188-48f3-92f5-de44f11c638a} executeQuery: Code: 721. DB::Exception: Function runningDifferenceStartingWithFirstValue is deprecated since its usage is error-prone (see docs).Please use proper window function or set `allow_deprecated_error_prone_window_functions` setting to enable it. (DEPRECATED_FUNCTION) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT runningDifferenceStartingWithFirstValue(NULL, NULL);) 2025.09.09 15:09:40.889967 [ 20345 ] {746bb343-4188-48f3-92f5-de44f11c638a} TCPHandler: Code: 721. DB::Exception: Function runningDifferenceStartingWithFirstValue is deprecated since its usage is error-prone (see docs).Please use proper window function or set `allow_deprecated_error_prone_window_functions` setting to enable it. (DEPRECATED_FUNCTION) 2025.09.09 15:09:41.022848 [ 20345 ] {dec488f8-8432-48bf-814f-8a4537b745a8} executeQuery: Code: 42. DB::Exception: Number of arguments for function s2CapContains doesn't match: passed 2, should be 3: In scope SELECT s2CapContains(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT s2CapContains(NULL, NULL);) 2025.09.09 15:09:41.029505 [ 20345 ] {dec488f8-8432-48bf-814f-8a4537b745a8} TCPHandler: Code: 42. DB::Exception: Number of arguments for function s2CapContains doesn't match: passed 2, should be 3: In scope SELECT s2CapContains(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:09:41.107325 [ 20345 ] {ddf9648c-7932-4f53-9650-315861adc5e2} executeQuery: Code: 42. DB::Exception: Number of arguments for function s2CapUnion doesn't match: passed 2, should be 4: In scope SELECT s2CapUnion(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT s2CapUnion(NULL, NULL);) 2025.09.09 15:09:41.127093 [ 20345 ] {ddf9648c-7932-4f53-9650-315861adc5e2} TCPHandler: Code: 42. DB::Exception: Number of arguments for function s2CapUnion doesn't match: passed 2, should be 4: In scope SELECT s2CapUnion(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:09:41.147840 [ 3080 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:09:41.311670 [ 3069 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:09:41.314068 [ 20345 ] {ce9d3913-e4c9-4a54-bb9a-c0073af0be91} executeQuery: Code: 42. DB::Exception: Number of arguments for function s2GetNeighbors doesn't match: passed 2, should be 1: In scope SELECT s2GetNeighbors(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT s2GetNeighbors(NULL, NULL);) 2025.09.09 15:09:41.319630 [ 20345 ] {ce9d3913-e4c9-4a54-bb9a-c0073af0be91} TCPHandler: Code: 42. DB::Exception: Number of arguments for function s2GetNeighbors doesn't match: passed 2, should be 1: In scope SELECT s2GetNeighbors(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:09:41.386168 [ 20345 ] {9ec7d80c-c4d0-4293-bc6d-b8a510b61d94} executeQuery: Code: 42. DB::Exception: Number of arguments for function s2RectAdd doesn't match: passed 2, should be 3: In scope SELECT s2RectAdd(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT s2RectAdd(NULL, NULL);) 2025.09.09 15:09:41.396244 [ 20345 ] {9ec7d80c-c4d0-4293-bc6d-b8a510b61d94} TCPHandler: Code: 42. DB::Exception: Number of arguments for function s2RectAdd doesn't match: passed 2, should be 3: In scope SELECT s2RectAdd(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:09:41.491722 [ 20345 ] {ac14d9f8-09a0-4907-b4e3-1812f7a7bc77} executeQuery: Code: 42. DB::Exception: Number of arguments for function s2RectContains doesn't match: passed 2, should be 3: In scope SELECT s2RectContains(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT s2RectContains(NULL, NULL);) 2025.09.09 15:09:41.498286 [ 20345 ] {ac14d9f8-09a0-4907-b4e3-1812f7a7bc77} TCPHandler: Code: 42. DB::Exception: Number of arguments for function s2RectContains doesn't match: passed 2, should be 3: In scope SELECT s2RectContains(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:09:41.559586 [ 20345 ] {d331fea2-43ec-41a4-90e7-aafe069b3e7d} executeQuery: Code: 42. DB::Exception: Number of arguments for function s2RectIntersection doesn't match: passed 2, should be 4: In scope SELECT s2RectIntersection(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT s2RectIntersection(NULL, NULL);) 2025.09.09 15:09:41.594518 [ 3109 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:09:41.628782 [ 20345 ] {d331fea2-43ec-41a4-90e7-aafe069b3e7d} TCPHandler: Code: 42. DB::Exception: Number of arguments for function s2RectIntersection doesn't match: passed 2, should be 4: In scope SELECT s2RectIntersection(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:09:41.636604 [ 19252 ] {669e173e-4946-428a-9803-12394a8b7acd} executeQuery: Code: 62. DB::Exception: Cannot TRUNCATE dictionary. (SYNTAX_ERROR) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:39352) (comment: 02504_regexp_dictionary_yaml_source.sh) (in query: drop dictionary regexp_dict1;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aac868e 4. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:262: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x00000000291f1adc 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x00000000291ed665 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x00000000291ebd68 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x00000000291eb7ed 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b382fc 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 11. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 15. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 16. asan_thread_start(void*) @ 0x000000000aa43059 17. ? @ 0x00007f35aab92ac3 18. ? @ 0x00007f35aac24850 2025.09.09 15:09:41.651312 [ 3081 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:09:41.659276 [ 19252 ] {669e173e-4946-428a-9803-12394a8b7acd} 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aac868e 4. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:262: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x00000000291f1adc 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x00000000291ed665 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x00000000291ebd68 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x00000000291eb7ed 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b382fc 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 11. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 15. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 16. asan_thread_start(void*) @ 0x000000000aa43059 17. ? @ 0x00007f35aab92ac3 18. ? @ 0x00007f35aac24850 2025.09.09 15:09:41.701687 [ 20345 ] {214d31cc-2731-4756-9456-e6192e1c508a} executeQuery: Code: 42. DB::Exception: Number of arguments for function s2RectUnion doesn't match: passed 2, should be 4: In scope SELECT s2RectUnion(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT s2RectUnion(NULL, NULL);) 2025.09.09 15:09:41.708602 [ 20345 ] {214d31cc-2731-4756-9456-e6192e1c508a} TCPHandler: Code: 42. DB::Exception: Number of arguments for function s2RectUnion doesn't match: passed 2, should be 4: In scope SELECT s2RectUnion(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:09:41.876569 [ 20345 ] {d0996214-3994-4eda-9a12-521b89644c95} executeQuery: Code: 42. DB::Exception: Number of arguments for function s2ToGeo doesn't match: passed 2, should be 1: In scope SELECT s2ToGeo(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT s2ToGeo(NULL, NULL);) 2025.09.09 15:09:41.906361 [ 20345 ] {d0996214-3994-4eda-9a12-521b89644c95} TCPHandler: Code: 42. DB::Exception: Number of arguments for function s2ToGeo doesn't match: passed 2, should be 1: In scope SELECT s2ToGeo(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:09:42.149889 [ 3185 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:09:42.314536 [ 3204 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:09:42.349351 [ 20345 ] {685a9b28-b5bd-4274-8543-2d6cc4b63bf1} executeQuery: Code: 63. DB::Exception: Aggregate function sequenceNextNode is experimental. Set `allow_experimental_funnel_functions` setting to enable it. (UNKNOWN_AGGREGATE_FUNCTION) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT sequenceNextNode(NULL, NULL);) 2025.09.09 15:09:42.365065 [ 20345 ] {685a9b28-b5bd-4274-8543-2d6cc4b63bf1} TCPHandler: Code: 63. DB::Exception: Aggregate function sequenceNextNode is experimental. Set `allow_experimental_funnel_functions` setting to enable it. (UNKNOWN_AGGREGATE_FUNCTION) 2025.09.09 15:09:42.597279 [ 3199 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:09:42.653930 [ 3211 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:09:42.766083 [ 20345 ] {c9010394-5081-4e8f-a2b1-d47208815a2f} executeQuery: Code: 42. DB::Exception: Number of arguments for function seriesPeriodDetectFFT doesn't match: passed 2, should be 1: In scope SELECT seriesPeriodDetectFFT(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT seriesPeriodDetectFFT(NULL, NULL);) 2025.09.09 15:09:42.779929 [ 20345 ] {c9010394-5081-4e8f-a2b1-d47208815a2f} TCPHandler: Code: 42. DB::Exception: Number of arguments for function seriesPeriodDetectFFT doesn't match: passed 2, should be 1: In scope SELECT seriesPeriodDetectFFT(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:09:42.824585 [ 20345 ] {a06d0998-5035-4d13-bddd-60194b7513d9} executeQuery: Code: 42. DB::Exception: Number of arguments for function serverTimezone doesn't match: passed 2, should be 0: In scope SELECT serverTimeZone(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT serverTimeZone(NULL, NULL);) 2025.09.09 15:09:42.829478 [ 20345 ] {a06d0998-5035-4d13-bddd-60194b7513d9} TCPHandler: Code: 42. DB::Exception: Number of arguments for function serverTimezone doesn't match: passed 2, should be 0: In scope SELECT serverTimeZone(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:09:42.878912 [ 20345 ] {155a071a-e17f-4212-98d2-b974927e7c93} executeQuery: Code: 42. DB::Exception: Number of arguments for function serverTimezone doesn't match: passed 2, should be 0: In scope SELECT serverTimezone(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT serverTimezone(NULL, NULL);) 2025.09.09 15:09:42.883243 [ 20345 ] {155a071a-e17f-4212-98d2-b974927e7c93} TCPHandler: Code: 42. DB::Exception: Number of arguments for function serverTimezone doesn't match: passed 2, should be 0: In scope SELECT serverTimezone(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:09:42.924120 [ 20345 ] {9bd40d36-d8fc-4580-af03-f1920b520e1e} executeQuery: Code: 42. DB::Exception: Number of arguments for function serverUUID doesn't match: passed 2, should be 0: In scope SELECT serverUUID(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT serverUUID(NULL, NULL);) 2025.09.09 15:09:42.928546 [ 20345 ] {9bd40d36-d8fc-4580-af03-f1920b520e1e} TCPHandler: Code: 42. DB::Exception: Number of arguments for function serverUUID doesn't match: passed 2, should be 0: In scope SELECT serverUUID(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:09:42.973418 [ 20345 ] {d96cc9d1-d535-4d89-9549-4df51e2d7999} executeQuery: Code: 42. DB::Exception: Number of arguments for function shardCount doesn't match: passed 2, should be 0: In scope SELECT shardCount(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT shardCount(NULL, NULL);) 2025.09.09 15:09:42.976523 [ 20345 ] {d96cc9d1-d535-4d89-9549-4df51e2d7999} TCPHandler: Code: 42. DB::Exception: Number of arguments for function shardCount doesn't match: passed 2, should be 0: In scope SELECT shardCount(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:09:43.013937 [ 20345 ] {20701ac7-fba8-4c81-bdef-ac74382a90e2} executeQuery: Code: 42. DB::Exception: Number of arguments for function shardNum doesn't match: passed 2, should be 0: In scope SELECT shardNum(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT shardNum(NULL, NULL);) 2025.09.09 15:09:43.018960 [ 20345 ] {20701ac7-fba8-4c81-bdef-ac74382a90e2} TCPHandler: Code: 42. DB::Exception: Number of arguments for function shardNum doesn't match: passed 2, should be 0: In scope SELECT shardNum(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:09:43.058780 [ 20345 ] {969106b9-8fd5-4cda-82f6-84de395ed641} executeQuery: Code: 42. DB::Exception: Number of arguments for function showCertificate doesn't match: passed 2, should be 0: In scope SELECT showCertificate(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT showCertificate(NULL, NULL);) 2025.09.09 15:09:43.072152 [ 20345 ] {969106b9-8fd5-4cda-82f6-84de395ed641} TCPHandler: Code: 42. DB::Exception: Number of arguments for function showCertificate doesn't match: passed 2, should be 0: In scope SELECT showCertificate(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:09:43.152367 [ 3207 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:09:43.161566 [ 20345 ] {e5c29b4d-8ee2-45f0-b441-593b6ef53056} executeQuery: Code: 42. DB::Exception: Number of arguments for function sigmoid doesn't match: passed 2, should be 1: In scope SELECT sigmoid(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT sigmoid(NULL, NULL);) 2025.09.09 15:09:43.164508 [ 20345 ] {e5c29b4d-8ee2-45f0-b441-593b6ef53056} TCPHandler: Code: 42. DB::Exception: Number of arguments for function sigmoid doesn't match: passed 2, should be 1: In scope SELECT sigmoid(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:09:43.202286 [ 20345 ] {4f068ede-87b1-42c6-8ac5-3fb062fff8a0} executeQuery: Code: 42. DB::Exception: Number of arguments for function sign doesn't match: passed 2, should be 1: In scope SELECT sign(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT sign(NULL, NULL);) 2025.09.09 15:09:43.206473 [ 20345 ] {4f068ede-87b1-42c6-8ac5-3fb062fff8a0} TCPHandler: Code: 42. DB::Exception: Number of arguments for function sign doesn't match: passed 2, should be 1: In scope SELECT sign(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:09:43.316665 [ 3169 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:09:43.599503 [ 2787 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:09:43.631989 [ 19252 ] {88db6a2b-fe75-48ff-8b3a-ca75ccbe19c2} executeQuery: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:39380) (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x0000000026f807e3 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x000000002853b6ad 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterSetQuery::execute() @ 0x00000000294f603b 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b382fc 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 15:09:43.634571 [ 19252 ] {88db6a2b-fe75-48ff-8b3a-ca75ccbe19c2} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x0000000026f807e3 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x000000002853b6ad 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterSetQuery::execute() @ 0x00000000294f603b 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b382fc 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 15:09:43.656369 [ 3065 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:09:43.688464 [ 20849 ] {700d4a05-74c3-4d14-aef2-7dd543c998c3} executeQuery: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:39392) (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x0000000026f807e3 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x000000002853b6ad 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterSetQuery::execute() @ 0x00000000294f603b 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b382fc 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 15:09:43.690334 [ 20849 ] {700d4a05-74c3-4d14-aef2-7dd543c998c3} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x0000000026f807e3 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x000000002853b6ad 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterSetQuery::execute() @ 0x00000000294f603b 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b382fc 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 15:09:43.975282 [ 20380 ] {632ba66f-840e-4617-b40a-384f011045ee} executeQuery: Code: 184. DB::Exception: Aggregate function max(x1) is found in GROUP BY in query. (ILLEGAL_AGGREGATION) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:39322) (comment: 02006_test_positional_arguments.sql) (in query: select max(x1), x2 from test group by 1, 2;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&) @ 0x000000000e9cb0ba 4. ./build_docker/./src/Analyzer/AggregationUtils.cpp:43: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x0000000028424cba 5. ./src/Analyzer/InDepthQueryTreeVisitor.h:0: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x0000000028424b15 6. ./contrib/llvm-project/libcxx/include/string:1499: DB::assertNoAggregateFunctionNodes(std::shared_ptr const&, String const&) @ 0x000000002842547b 7. ./contrib/llvm-project/libcxx/include/string:1499: DB::validateAggregates(std::shared_ptr const&, DB::AggregatesValidationParams) @ 0x000000002841bd4c 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002835c627 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000028359104 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000028357f0d 11. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002921bdcc 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&) @ 0x000000002941f313 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&) @ 0x0000000029419aef 14. ./contrib/llvm-project/libcxx/include/vector:432: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000029421f5d 15. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000029344c1b 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*) @ 0x0000000029b3703b 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 19. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 23. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 24. asan_thread_start(void*) @ 0x000000000aa43059 25. ? @ 0x00007f35aab92ac3 26. ? @ 0x00007f35aac24850 2025.09.09 15:09:43.978927 [ 20380 ] {632ba66f-840e-4617-b40a-384f011045ee} TCPHandler: Code: 184. DB::Exception: Aggregate function max(x1) is found in GROUP BY in query. (ILLEGAL_AGGREGATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&) @ 0x000000000e9cb0ba 4. ./build_docker/./src/Analyzer/AggregationUtils.cpp:43: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x0000000028424cba 5. ./src/Analyzer/InDepthQueryTreeVisitor.h:0: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x0000000028424b15 6. ./contrib/llvm-project/libcxx/include/string:1499: DB::assertNoAggregateFunctionNodes(std::shared_ptr const&, String const&) @ 0x000000002842547b 7. ./contrib/llvm-project/libcxx/include/string:1499: DB::validateAggregates(std::shared_ptr const&, DB::AggregatesValidationParams) @ 0x000000002841bd4c 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002835c627 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000028359104 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000028357f0d 11. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002921bdcc 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&) @ 0x000000002941f313 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&) @ 0x0000000029419aef 14. ./contrib/llvm-project/libcxx/include/vector:432: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000029421f5d 15. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000029344c1b 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*) @ 0x0000000029b3703b 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 19. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 23. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 24. asan_thread_start(void*) @ 0x000000000aa43059 25. ? @ 0x00007f35aab92ac3 26. ? @ 0x00007f35aac24850 2025.09.09 15:09:44.078717 [ 20380 ] {c071c4b3-db92-405e-9ae0-4024139a90e9} executeQuery: Code: 184. DB::Exception: Aggregate function max(x1) is found in GROUP BY in query. (ILLEGAL_AGGREGATION) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:39322) (comment: 02006_test_positional_arguments.sql) (in query: select 1 + max(x1), x2 from test group by 1, 2;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&) @ 0x000000000e9cb0ba 4. ./build_docker/./src/Analyzer/AggregationUtils.cpp:43: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x0000000028424cba 5. ./src/Analyzer/InDepthQueryTreeVisitor.h:0: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x0000000028424b15 6. ./src/Analyzer/InDepthQueryTreeVisitor.h:0: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x0000000028424b15 7. ./src/Analyzer/InDepthQueryTreeVisitor.h:0: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x0000000028424b15 8. ./contrib/llvm-project/libcxx/include/string:1499: DB::assertNoAggregateFunctionNodes(std::shared_ptr const&, String const&) @ 0x000000002842547b 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::validateAggregates(std::shared_ptr const&, DB::AggregatesValidationParams) @ 0x000000002841bd4c 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002835c627 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000028359104 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000028357f0d 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002921bdcc 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&) @ 0x000000002941f313 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&) @ 0x0000000029419aef 16. ./contrib/llvm-project/libcxx/include/vector:432: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000029421f5d 17. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000029344c1b 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*) @ 0x0000000029b3703b 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 21. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 25. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 26. asan_thread_start(void*) @ 0x000000000aa43059 27. ? @ 0x00007f35aab92ac3 28. ? @ 0x00007f35aac24850 2025.09.09 15:09:44.083302 [ 20380 ] {c071c4b3-db92-405e-9ae0-4024139a90e9} TCPHandler: Code: 184. DB::Exception: Aggregate function max(x1) is found in GROUP BY in query. (ILLEGAL_AGGREGATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&) @ 0x000000000e9cb0ba 4. ./build_docker/./src/Analyzer/AggregationUtils.cpp:43: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x0000000028424cba 5. ./src/Analyzer/InDepthQueryTreeVisitor.h:0: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x0000000028424b15 6. ./src/Analyzer/InDepthQueryTreeVisitor.h:0: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x0000000028424b15 7. ./src/Analyzer/InDepthQueryTreeVisitor.h:0: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x0000000028424b15 8. ./contrib/llvm-project/libcxx/include/string:1499: DB::assertNoAggregateFunctionNodes(std::shared_ptr const&, String const&) @ 0x000000002842547b 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::validateAggregates(std::shared_ptr const&, DB::AggregatesValidationParams) @ 0x000000002841bd4c 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002835c627 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000028359104 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000028357f0d 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002921bdcc 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&) @ 0x000000002941f313 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&) @ 0x0000000029419aef 16. ./contrib/llvm-project/libcxx/include/vector:432: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000029421f5d 17. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000029344c1b 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*) @ 0x0000000029b3703b 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 21. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 25. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 26. asan_thread_start(void*) @ 0x000000000aa43059 27. ? @ 0x00007f35aab92ac3 28. ? @ 0x00007f35aac24850 2025.09.09 15:09:44.103351 [ 19252 ] {c5dd14aa-1c72-4ace-9e75-510403518142} 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.10505.altinitytest (altinity build)) (from [::1]:39380) (in query: CREATE WINDOW VIEW 01070_window_view_watch_events.wv ENGINE Memory WATERMARK=ASCENDING AS SELECT count(a) AS count, tumbleEnd(wid) AS w_end FROM 01070_window_view_watch_events.mt GROUP BY tumble(timestamp, INTERVAL '5' 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aac868e 4. ./build_docker/./src/Storages/WindowView/StorageWindowView.cpp:1767: DB::StorageWindowView::throwIfWindowViewIsDisabled(std::shared_ptr) const @ 0x000000002cc8350d 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) @ 0x000000002cc9d47d 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&) @ 0x000000002ccc627c 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::shared_ptr std::__function::__policy_invoker (DB::StorageFactory::Arguments const&)>::__call_impl (DB::StorageFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::StorageFactory::Arguments const&) @ 0x000000002ccb64c5 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 @ 0x000000002b77bf53 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291b9254 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291ac835 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000291c3415 12. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b382fc 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 15. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 19. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 20. asan_thread_start(void*) @ 0x000000000aa43059 21. ? @ 0x00007f35aab92ac3 22. ? @ 0x00007f35aac24850 2025.09.09 15:09:44.105594 [ 19252 ] {c5dd14aa-1c72-4ace-9e75-510403518142} 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aac868e 4. ./build_docker/./src/Storages/WindowView/StorageWindowView.cpp:1767: DB::StorageWindowView::throwIfWindowViewIsDisabled(std::shared_ptr) const @ 0x000000002cc8350d 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) @ 0x000000002cc9d47d 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&) @ 0x000000002ccc627c 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::shared_ptr std::__function::__policy_invoker (DB::StorageFactory::Arguments const&)>::__call_impl (DB::StorageFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::StorageFactory::Arguments const&) @ 0x000000002ccb64c5 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 @ 0x000000002b77bf53 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291b9254 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291ac835 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000291c3415 12. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b382fc 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 15. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 19. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 20. asan_thread_start(void*) @ 0x000000000aa43059 21. ? @ 0x00007f35aab92ac3 22. ? @ 0x00007f35aac24850 2025.09.09 15:09:44.136128 [ 20380 ] {b75eb89e-f439-4d2b-b5da-bb59f546de19} executeQuery: Code: 184. DB::Exception: Aggregate function max(x1) is found in GROUP BY in query. (ILLEGAL_AGGREGATION) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:39322) (comment: 02006_test_positional_arguments.sql) (in query: select max(x1), x2 from test group by -2, -1;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&) @ 0x000000000e9cb0ba 4. ./build_docker/./src/Analyzer/AggregationUtils.cpp:43: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x0000000028424cba 5. ./src/Analyzer/InDepthQueryTreeVisitor.h:0: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x0000000028424b15 6. ./contrib/llvm-project/libcxx/include/string:1499: DB::assertNoAggregateFunctionNodes(std::shared_ptr const&, String const&) @ 0x000000002842547b 7. ./contrib/llvm-project/libcxx/include/string:1499: DB::validateAggregates(std::shared_ptr const&, DB::AggregatesValidationParams) @ 0x000000002841bd4c 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002835c627 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000028359104 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000028357f0d 11. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002921bdcc 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&) @ 0x000000002941f313 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&) @ 0x0000000029419aef 14. ./contrib/llvm-project/libcxx/include/vector:432: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000029421f5d 15. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000029344c1b 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*) @ 0x0000000029b3703b 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 19. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 23. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 24. asan_thread_start(void*) @ 0x000000000aa43059 25. ? @ 0x00007f35aab92ac3 26. ? @ 0x00007f35aac24850 2025.09.09 15:09:44.139553 [ 20380 ] {b75eb89e-f439-4d2b-b5da-bb59f546de19} TCPHandler: Code: 184. DB::Exception: Aggregate function max(x1) is found in GROUP BY in query. (ILLEGAL_AGGREGATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&) @ 0x000000000e9cb0ba 4. ./build_docker/./src/Analyzer/AggregationUtils.cpp:43: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x0000000028424cba 5. ./src/Analyzer/InDepthQueryTreeVisitor.h:0: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x0000000028424b15 6. ./contrib/llvm-project/libcxx/include/string:1499: DB::assertNoAggregateFunctionNodes(std::shared_ptr const&, String const&) @ 0x000000002842547b 7. ./contrib/llvm-project/libcxx/include/string:1499: DB::validateAggregates(std::shared_ptr const&, DB::AggregatesValidationParams) @ 0x000000002841bd4c 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002835c627 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000028359104 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000028357f0d 11. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002921bdcc 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&) @ 0x000000002941f313 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&) @ 0x0000000029419aef 14. ./contrib/llvm-project/libcxx/include/vector:432: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000029421f5d 15. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000029344c1b 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*) @ 0x0000000029b3703b 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 19. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 23. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 24. asan_thread_start(void*) @ 0x000000000aa43059 25. ? @ 0x00007f35aab92ac3 26. ? @ 0x00007f35aac24850 2025.09.09 15:09:44.154280 [ 2845 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:09:44.231310 [ 20380 ] {99c8ff8c-c861-4350-b944-60605ee581f5} executeQuery: Code: 184. DB::Exception: Aggregate function max(x1) is found in GROUP BY in query. (ILLEGAL_AGGREGATION) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:39322) (comment: 02006_test_positional_arguments.sql) (in query: select 1 + max(x1), x2 from test group by -2, -1;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&) @ 0x000000000e9cb0ba 4. ./build_docker/./src/Analyzer/AggregationUtils.cpp:43: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x0000000028424cba 5. ./src/Analyzer/InDepthQueryTreeVisitor.h:0: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x0000000028424b15 6. ./src/Analyzer/InDepthQueryTreeVisitor.h:0: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x0000000028424b15 7. ./src/Analyzer/InDepthQueryTreeVisitor.h:0: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x0000000028424b15 8. ./contrib/llvm-project/libcxx/include/string:1499: DB::assertNoAggregateFunctionNodes(std::shared_ptr const&, String const&) @ 0x000000002842547b 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::validateAggregates(std::shared_ptr const&, DB::AggregatesValidationParams) @ 0x000000002841bd4c 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002835c627 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000028359104 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000028357f0d 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002921bdcc 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&) @ 0x000000002941f313 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&) @ 0x0000000029419aef 16. ./contrib/llvm-project/libcxx/include/vector:432: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000029421f5d 17. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000029344c1b 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*) @ 0x0000000029b3703b 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 21. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 25. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 26. asan_thread_start(void*) @ 0x000000000aa43059 27. ? @ 0x00007f35aab92ac3 28. ? @ 0x00007f35aac24850 2025.09.09 15:09:44.243262 [ 20380 ] {99c8ff8c-c861-4350-b944-60605ee581f5} TCPHandler: Code: 184. DB::Exception: Aggregate function max(x1) is found in GROUP BY in query. (ILLEGAL_AGGREGATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&) @ 0x000000000e9cb0ba 4. ./build_docker/./src/Analyzer/AggregationUtils.cpp:43: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x0000000028424cba 5. ./src/Analyzer/InDepthQueryTreeVisitor.h:0: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x0000000028424b15 6. ./src/Analyzer/InDepthQueryTreeVisitor.h:0: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x0000000028424b15 7. ./src/Analyzer/InDepthQueryTreeVisitor.h:0: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x0000000028424b15 8. ./contrib/llvm-project/libcxx/include/string:1499: DB::assertNoAggregateFunctionNodes(std::shared_ptr const&, String const&) @ 0x000000002842547b 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::validateAggregates(std::shared_ptr const&, DB::AggregatesValidationParams) @ 0x000000002841bd4c 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002835c627 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000028359104 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000028357f0d 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002921bdcc 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&) @ 0x000000002941f313 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&) @ 0x0000000029419aef 16. ./contrib/llvm-project/libcxx/include/vector:432: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000029421f5d 17. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000029344c1b 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*) @ 0x0000000029b3703b 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 21. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 25. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 26. asan_thread_start(void*) @ 0x000000000aa43059 27. ? @ 0x00007f35aab92ac3 28. ? @ 0x00007f35aac24850 2025.09.09 15:09:44.319128 [ 2900 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:09:44.342512 [ 19252 ] {05eab6ce-ae71-4f6c-9332-00f1bc9ea0f2} executeQuery: Code: 60. DB::Exception: Table `01070_window_view_watch_events`.wv does not exist. (UNKNOWN_TABLE) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:39380) (in query: WATCH 01070_window_view_watch_events.wv EVENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000aad4b34 4. ./build_docker/./src/Interpreters/InterpreterWatchQuery.cpp:66: DB::InterpreterWatchQuery::buildQueryPipeline() @ 0x0000000029c2869b 5. ./build_docker/./src/Interpreters/InterpreterWatchQuery.cpp:0: DB::InterpreterWatchQuery::execute() @ 0x0000000029c2723d 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b382fc 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 9. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 13. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 14. asan_thread_start(void*) @ 0x000000000aa43059 15. ? @ 0x00007f35aab92ac3 16. ? @ 0x00007f35aac24850 2025.09.09 15:09:44.347200 [ 20345 ] {ce3e3d18-f3eb-4642-ad07-aba97afbecf4} executeQuery: Code: 42. DB::Exception: Number of arguments for function sin doesn't match: passed 2, should be 1: In scope SELECT sin(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT sin(NULL, NULL);) 2025.09.09 15:09:44.350138 [ 19252 ] {05eab6ce-ae71-4f6c-9332-00f1bc9ea0f2} TCPHandler: Code: 60. DB::Exception: Table `01070_window_view_watch_events`.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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000aad4b34 4. ./build_docker/./src/Interpreters/InterpreterWatchQuery.cpp:66: DB::InterpreterWatchQuery::buildQueryPipeline() @ 0x0000000029c2869b 5. ./build_docker/./src/Interpreters/InterpreterWatchQuery.cpp:0: DB::InterpreterWatchQuery::execute() @ 0x0000000029c2723d 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b382fc 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 9. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 13. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 14. asan_thread_start(void*) @ 0x000000000aa43059 15. ? @ 0x00007f35aab92ac3 16. ? @ 0x00007f35aac24850 2025.09.09 15:09:44.352512 [ 20345 ] {ce3e3d18-f3eb-4642-ad07-aba97afbecf4} TCPHandler: Code: 42. DB::Exception: Number of arguments for function sin doesn't match: passed 2, should be 1: In scope SELECT sin(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:09:44.603664 [ 2928 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:09:44.660580 [ 2874 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:09:44.740222 [ 20345 ] {41c4ed11-e000-42aa-8b7f-feb7310bb78e} executeQuery: Code: 42. DB::Exception: Number of arguments for function sinh doesn't match: passed 2, should be 1: In scope SELECT sinh(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT sinh(NULL, NULL);) 2025.09.09 15:09:44.746037 [ 20345 ] {41c4ed11-e000-42aa-8b7f-feb7310bb78e} TCPHandler: Code: 42. DB::Exception: Number of arguments for function sinh doesn't match: passed 2, should be 1: In scope SELECT sinh(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:09:45.156859 [ 2946 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:09:45.321469 [ 2955 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:09:45.668607 [ 2837 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:09:45.669388 [ 2794 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:09:45.707641 [ 20345 ] {f3fe0e23-ae8d-4948-9f1c-ba3ff8ccdbf5} executeQuery: Code: 42. DB::Exception: Number of arguments for function sleep doesn't match: passed 2, should be 1: In scope SELECT sleep(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT sleep(NULL, NULL);) 2025.09.09 15:09:45.710560 [ 20345 ] {f3fe0e23-ae8d-4948-9f1c-ba3ff8ccdbf5} TCPHandler: Code: 42. DB::Exception: Number of arguments for function sleep doesn't match: passed 2, should be 1: In scope SELECT sleep(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:09:45.827161 [ 20345 ] {118737ae-e8b2-410b-a735-be41be57dfde} executeQuery: Code: 42. DB::Exception: Number of arguments for function sleepEachRow doesn't match: passed 2, should be 1: In scope SELECT sleepEachRow(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT sleepEachRow(NULL, NULL);) 2025.09.09 15:09:45.833530 [ 20345 ] {118737ae-e8b2-410b-a735-be41be57dfde} TCPHandler: Code: 42. DB::Exception: Number of arguments for function sleepEachRow doesn't match: passed 2, should be 1: In scope SELECT sleepEachRow(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:09:46.158639 [ 2957 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:09:46.328985 [ 2944 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:09:46.358996 [ 20345 ] {f1b04dfc-5850-4195-a048-18392555bb64} executeQuery: Code: 42. DB::Exception: Number of arguments for function soundex doesn't match: passed 2, should be 1: In scope SELECT soundex(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT soundex(NULL, NULL);) 2025.09.09 15:09:46.362202 [ 20345 ] {f1b04dfc-5850-4195-a048-18392555bb64} TCPHandler: Code: 42. DB::Exception: Number of arguments for function soundex doesn't match: passed 2, should be 1: In scope SELECT soundex(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:09:46.408760 [ 20345 ] {da890996-c5f0-4b14-92fb-59ab0fb6bf23} executeQuery: Code: 42. DB::Exception: Number of arguments for function space doesn't match: passed 2, should be 1: In scope SELECT space(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT space(NULL, NULL);) 2025.09.09 15:09:46.424658 [ 20345 ] {da890996-c5f0-4b14-92fb-59ab0fb6bf23} TCPHandler: Code: 42. DB::Exception: Number of arguments for function space doesn't match: passed 2, should be 1: In scope SELECT space(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:09:46.670685 [ 3000 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:09:46.671268 [ 3013 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:09:46.937618 [ 20380 ] {d84f5438-8e86-4029-afdd-8aecfbf500c7} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=790, jobs=741). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:39322) (comment: 02006_test_positional_arguments.sql) (in query: select b from (select 5 as a, 'Hello' as b group by a);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af872f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af7b2d1 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af7c3f3 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d36920d 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000002d369e5f 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processOrdinaryQuery() @ 0x000000002d18af7b 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d17644a 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 15. asan_thread_start(void*) @ 0x000000000aa43059 16. ? @ 0x00007f35aab92ac3 17. ? @ 0x00007f35aac24850 2025.09.09 15:09:46.938815 [ 20380 ] {d84f5438-8e86-4029-afdd-8aecfbf500c7} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=790, 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af872f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af7b2d1 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af7c3f3 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d36920d 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000002d369e5f 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processOrdinaryQuery() @ 0x000000002d18af7b 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d17644a 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 15. asan_thread_start(void*) @ 0x000000000aa43059 16. ? @ 0x00007f35aab92ac3 17. ? @ 0x00007f35aac24850 2025.09.09 15:09:47.160530 [ 3022 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:09:47.210562 [ 20379 ] {f04e8f6b-f531-4140-a604-cc7cc7155579} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:36784) (comment: 02006_test_positional_arguments.sql) (in query: DROP DATABASE IF EXISTS test_7d5yxxra ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aac868e 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x00000000286b57c7 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x00000000291f5630 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:361: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000291edc97 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x00000000291ebf11 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x00000000291eb7ed 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b382fc 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1529: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000029b3ed3f 11. ./build_docker/./src/Server/HTTPHandler.cpp:529: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000002d0662d1 12. ./build_docker/./src/Server/HTTPHandler.cpp:705: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000002d06d139 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000002d1cc337 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 18. asan_thread_start(void*) @ 0x000000000aa43059 19. ? @ 0x00007f35aab92ac3 20. ? @ 0x00007f35aac24850 2025.09.09 15:09:47.212708 [ 20379 ] {f04e8f6b-f531-4140-a604-cc7cc7155579} DynamicQueryHandler: Code: 219. DB::Exception: New table 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aac868e 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x00000000286b57c7 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x00000000291f5630 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:361: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000291edc97 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x00000000291ebf11 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x00000000291eb7ed 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b382fc 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1529: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000029b3ed3f 11. ./build_docker/./src/Server/HTTPHandler.cpp:529: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000002d0662d1 12. ./build_docker/./src/Server/HTTPHandler.cpp:705: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000002d06d139 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000002d1cc337 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 18. asan_thread_start(void*) @ 0x000000000aa43059 19. ? @ 0x00007f35aab92ac3 20. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:09:47.332336 [ 3106 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:09:47.370929 [ 3722 ] {c73a86e1-fb84-4821-8bac-c42ec4ffa5d0} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:36786) (comment: 02006_test_positional_arguments.sql) (in query: DROP DATABASE IF EXISTS test_7d5yxxra ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aac868e 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x00000000286b57c7 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x00000000291f5630 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:361: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000291edc97 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x00000000291ebf11 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x00000000291eb7ed 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b382fc 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1529: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000029b3ed3f 11. ./build_docker/./src/Server/HTTPHandler.cpp:529: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000002d0662d1 12. ./build_docker/./src/Server/HTTPHandler.cpp:705: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000002d06d139 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000002d1cc337 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 18. asan_thread_start(void*) @ 0x000000000aa43059 19. ? @ 0x00007f35aab92ac3 20. ? @ 0x00007f35aac24850 2025.09.09 15:09:47.374684 [ 3722 ] {c73a86e1-fb84-4821-8bac-c42ec4ffa5d0} DynamicQueryHandler: Code: 219. DB::Exception: New table 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aac868e 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x00000000286b57c7 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x00000000291f5630 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:361: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000291edc97 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x00000000291ebf11 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x00000000291eb7ed 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b382fc 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1529: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000029b3ed3f 11. ./build_docker/./src/Server/HTTPHandler.cpp:529: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000002d0662d1 12. ./build_docker/./src/Server/HTTPHandler.cpp:705: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000002d06d139 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000002d1cc337 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 18. asan_thread_start(void*) @ 0x000000000aa43059 19. ? @ 0x00007f35aab92ac3 20. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:09:47.479573 [ 20345 ] {02257940-95f7-475e-bb8d-fdcc54b5ba85} executeQuery: Code: 42. DB::Exception: Number of arguments for function sqidDecode doesn't match: passed 2, should be 1: In scope SELECT sqidDecode(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT sqidDecode(NULL, NULL);) 2025.09.09 15:09:47.492503 [ 20345 ] {02257940-95f7-475e-bb8d-fdcc54b5ba85} TCPHandler: Code: 42. DB::Exception: Number of arguments for function sqidDecode doesn't match: passed 2, should be 1: In scope SELECT sqidDecode(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:09:47.673305 [ 3114 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:09:47.675553 [ 3109 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:09:47.865634 [ 20345 ] {42e610da-4364-4c68-908c-608ab9bc096e} executeQuery: Code: 42. DB::Exception: Number of arguments for function sqrt doesn't match: passed 2, should be 1: In scope SELECT sqrt(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT sqrt(NULL, NULL);) 2025.09.09 15:09:47.870070 [ 20345 ] {42e610da-4364-4c68-908c-608ab9bc096e} TCPHandler: Code: 42. DB::Exception: Number of arguments for function sqrt doesn't match: passed 2, should be 1: In scope SELECT sqrt(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:09:48.162941 [ 3172 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:09:48.335437 [ 3192 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:09:48.466166 [ 20345 ] {479dbd22-69a7-4bb1-a44c-ee3caedad16d} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=1, jobs=1). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT stddevPopStable(NULL, NULL);) 2025.09.09 15:09:48.469817 [ 20345 ] {479dbd22-69a7-4bb1-a44c-ee3caedad16d} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=1, jobs=1). (CANNOT_SCHEDULE_TASK) 2025.09.09 15:09:48.676525 [ 3201 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:09:48.677811 [ 3233 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:09:48.864546 [ 20345 ] {7b7c729f-71d7-4b46-aa24-91d46d56c660} executeQuery: Code: 344. DB::Exception: Natural language processing function 'stem' is experimental. Set `allow_experimental_nlp_functions` setting to enable it. (SUPPORT_IS_DISABLED) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT stem(NULL, NULL);) 2025.09.09 15:09:48.868559 [ 20345 ] {7b7c729f-71d7-4b46-aa24-91d46d56c660} TCPHandler: Code: 344. DB::Exception: Natural language processing function 'stem' is experimental. Set `allow_experimental_nlp_functions` setting to enable it. (SUPPORT_IS_DISABLED) 2025.09.09 15:09:49.168621 [ 2745 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:09:49.344363 [ 2748 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:09:49.628055 [ 20345 ] {5c2a8c37-7bc8-4bd4-8a21-a28a2889c453} executeQuery: Code: 42. DB::Exception: Number of arguments for function stringToH3 doesn't match: passed 2, should be 1: In scope SELECT stringToH3(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT stringToH3(NULL, NULL);) 2025.09.09 15:09:49.631139 [ 20345 ] {5c2a8c37-7bc8-4bd4-8a21-a28a2889c453} TCPHandler: Code: 42. DB::Exception: Number of arguments for function stringToH3 doesn't match: passed 2, should be 1: In scope SELECT stringToH3(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:09:49.691372 [ 2783 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:09:49.691766 [ 2771 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:09:49.808113 [ 20345 ] {3041d250-119d-49bb-b113-661b3da9fbec} executeQuery: Code: 43. DB::Exception: Illegal type Nullable(Nothing) of the first argument of function structureToCapnProtoSchema, expected constant string: In scope SELECT structureToCapnProtoSchema(NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT structureToCapnProtoSchema(NULL, NULL);) 2025.09.09 15:09:49.812442 [ 20345 ] {3041d250-119d-49bb-b113-661b3da9fbec} TCPHandler: Code: 43. DB::Exception: Illegal type Nullable(Nothing) of the first argument of function structureToCapnProtoSchema, expected constant string: In scope SELECT structureToCapnProtoSchema(NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.09.09 15:09:49.895749 [ 20345 ] {4dbca073-66ab-4616-98ea-c5a429cf64c8} executeQuery: Code: 43. DB::Exception: Illegal type Nullable(Nothing) of the first argument of function structureToProtobufSchema, expected constant string: In scope SELECT structureToProtobufSchema(NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT structureToProtobufSchema(NULL, NULL);) 2025.09.09 15:09:49.901386 [ 20345 ] {4dbca073-66ab-4616-98ea-c5a429cf64c8} TCPHandler: Code: 43. DB::Exception: Illegal type Nullable(Nothing) of the first argument of function structureToProtobufSchema, expected constant string: In scope SELECT structureToProtobufSchema(NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.09.09 15:09:50.177915 [ 20345 ] {262b1775-5d53-474c-8e1f-344b6121bc87} executeQuery: Code: 42. DB::Exception: Number of arguments for function subBitmap doesn't match: passed 2, should be 3: In scope SELECT subBitmap(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT subBitmap(NULL, NULL);) 2025.09.09 15:09:50.178622 [ 2875 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:09:50.186945 [ 20345 ] {262b1775-5d53-474c-8e1f-344b6121bc87} TCPHandler: Code: 42. DB::Exception: Number of arguments for function subBitmap doesn't match: passed 2, should be 3: In scope SELECT subBitmap(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:09:50.328033 [ 20379 ] {3ea41664-8f93-40fc-b3a0-089977ace3c0} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:43380) (comment: 01354_tuple_low_cardinality_array_mapped_bug.sql) (in query: DROP DATABASE IF EXISTS test_vh7268nq ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aac868e 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x00000000286b57c7 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x00000000291f5630 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:361: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000291edc97 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x00000000291ebf11 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x00000000291eb7ed 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b382fc 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1529: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000029b3ed3f 11. ./build_docker/./src/Server/HTTPHandler.cpp:529: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000002d0662d1 12. ./build_docker/./src/Server/HTTPHandler.cpp:705: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000002d06d139 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000002d1cc337 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 18. asan_thread_start(void*) @ 0x000000000aa43059 19. ? @ 0x00007f35aab92ac3 20. ? @ 0x00007f35aac24850 2025.09.09 15:09:50.331377 [ 20379 ] {3ea41664-8f93-40fc-b3a0-089977ace3c0} DynamicQueryHandler: Code: 219. DB::Exception: New table 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aac868e 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x00000000286b57c7 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x00000000291f5630 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:361: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000291edc97 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x00000000291ebf11 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x00000000291eb7ed 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b382fc 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1529: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000029b3ed3f 11. ./build_docker/./src/Server/HTTPHandler.cpp:529: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000002d0662d1 12. ./build_docker/./src/Server/HTTPHandler.cpp:705: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000002d06d139 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000002d1cc337 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 18. asan_thread_start(void*) @ 0x000000000aa43059 19. ? @ 0x00007f35aab92ac3 20. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:09:50.350680 [ 2829 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:09:50.410130 [ 20380 ] {94fa1cfb-0015-4b82-900c-f449201ce82f} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:43386) (comment: 01354_tuple_low_cardinality_array_mapped_bug.sql) (in query: DROP DATABASE IF EXISTS test_vh7268nq ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aac868e 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x00000000286b57c7 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x00000000291f5630 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:361: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000291edc97 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x00000000291ebf11 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x00000000291eb7ed 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b382fc 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1529: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000029b3ed3f 11. ./build_docker/./src/Server/HTTPHandler.cpp:529: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000002d0662d1 12. ./build_docker/./src/Server/HTTPHandler.cpp:705: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000002d06d139 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000002d1cc337 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 18. asan_thread_start(void*) @ 0x000000000aa43059 19. ? @ 0x00007f35aab92ac3 20. ? @ 0x00007f35aac24850 2025.09.09 15:09:50.481561 [ 20380 ] {94fa1cfb-0015-4b82-900c-f449201ce82f} DynamicQueryHandler: Code: 219. DB::Exception: New table 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aac868e 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x00000000286b57c7 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x00000000291f5630 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:361: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000291edc97 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x00000000291ebf11 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x00000000291eb7ed 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b382fc 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1529: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000029b3ed3f 11. ./build_docker/./src/Server/HTTPHandler.cpp:529: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000002d0662d1 12. ./build_docker/./src/Server/HTTPHandler.cpp:705: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000002d06d139 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000002d1cc337 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 18. asan_thread_start(void*) @ 0x000000000aa43059 19. ? @ 0x00007f35aab92ac3 20. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:09:50.598121 [ 20379 ] {d5e956a8-23ba-4e71-918c-aad9597cc660} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:43398) (comment: 01354_tuple_low_cardinality_array_mapped_bug.sql) (in query: DROP DATABASE IF EXISTS test_vh7268nq ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aac868e 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x00000000286b57c7 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x00000000291f5630 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:361: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000291edc97 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x00000000291ebf11 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x00000000291eb7ed 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b382fc 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1529: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000029b3ed3f 11. ./build_docker/./src/Server/HTTPHandler.cpp:529: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000002d0662d1 12. ./build_docker/./src/Server/HTTPHandler.cpp:705: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000002d06d139 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000002d1cc337 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 18. asan_thread_start(void*) @ 0x000000000aa43059 19. ? @ 0x00007f35aab92ac3 20. ? @ 0x00007f35aac24850 2025.09.09 15:09:50.603638 [ 20379 ] {d5e956a8-23ba-4e71-918c-aad9597cc660} DynamicQueryHandler: Code: 219. DB::Exception: New table 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aac868e 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x00000000286b57c7 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x00000000291f5630 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:361: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000291edc97 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x00000000291ebf11 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x00000000291eb7ed 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b382fc 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1529: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000029b3ed3f 11. ./build_docker/./src/Server/HTTPHandler.cpp:529: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000002d0662d1 12. ./build_docker/./src/Server/HTTPHandler.cpp:705: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000002d06d139 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000002d1cc337 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 18. asan_thread_start(void*) @ 0x000000000aa43059 19. ? @ 0x00007f35aab92ac3 20. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:09:50.690512 [ 20345 ] {cf3b1cfb-e3b2-41c7-8979-823d3429fe83} executeQuery: Code: 42. DB::Exception: Number of arguments for function substringIndex doesn't match: passed 2, should be 3: In scope SELECT substringIndex(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT substringIndex(NULL, NULL);) 2025.09.09 15:09:50.694133 [ 2909 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:09:50.695061 [ 2917 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:09:50.696361 [ 20345 ] {cf3b1cfb-e3b2-41c7-8979-823d3429fe83} TCPHandler: Code: 42. DB::Exception: Number of arguments for function substringIndex doesn't match: passed 2, should be 3: In scope SELECT substringIndex(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:09:50.784580 [ 20345 ] {efa0fe82-2358-40a3-bc51-2a85f5d30baa} executeQuery: Code: 42. DB::Exception: Number of arguments for function substringIndexUTF8 doesn't match: passed 2, should be 3: In scope SELECT substringIndexUTF8(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT substringIndexUTF8(NULL, NULL);) 2025.09.09 15:09:50.788773 [ 20380 ] {ec80c1b5-2a4e-4579-9eb6-429450d7f724} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:43402) (comment: 01354_tuple_low_cardinality_array_mapped_bug.sql) (in query: DROP DATABASE IF EXISTS test_vh7268nq ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aac868e 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x00000000286b57c7 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x00000000291f5630 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:361: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000291edc97 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x00000000291ebf11 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x00000000291eb7ed 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b382fc 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1529: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000029b3ed3f 11. ./build_docker/./src/Server/HTTPHandler.cpp:529: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000002d0662d1 12. ./build_docker/./src/Server/HTTPHandler.cpp:705: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000002d06d139 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000002d1cc337 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 18. asan_thread_start(void*) @ 0x000000000aa43059 19. ? @ 0x00007f35aab92ac3 20. ? @ 0x00007f35aac24850 2025.09.09 15:09:50.791144 [ 20345 ] {efa0fe82-2358-40a3-bc51-2a85f5d30baa} TCPHandler: Code: 42. DB::Exception: Number of arguments for function substringIndexUTF8 doesn't match: passed 2, should be 3: In scope SELECT substringIndexUTF8(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:09:50.793364 [ 20380 ] {ec80c1b5-2a4e-4579-9eb6-429450d7f724} DynamicQueryHandler: Code: 219. DB::Exception: New table 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aac868e 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x00000000286b57c7 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x00000000291f5630 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:361: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000291edc97 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x00000000291ebf11 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x00000000291eb7ed 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b382fc 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1529: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000029b3ed3f 11. ./build_docker/./src/Server/HTTPHandler.cpp:529: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000002d0662d1 12. ./build_docker/./src/Server/HTTPHandler.cpp:705: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000002d06d139 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000002d1cc337 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 18. asan_thread_start(void*) @ 0x000000000aa43059 19. ? @ 0x00007f35aab92ac3 20. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:09:51.181510 [ 2833 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:09:51.354064 [ 2905 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:09:51.696353 [ 2867 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:09:51.697123 [ 2941 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:09:52.183808 [ 2988 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:09:52.380744 [ 2972 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:09:52.698275 [ 3023 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:09:52.699808 [ 3002 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:09:53.186688 [ 3033 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:09:53.382702 [ 3046 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:09:53.700786 [ 3100 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:09:53.702146 [ 3067 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:09:54.189697 [ 3163 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:09:54.201260 [ 20345 ] {d22d8902-5f62-49ba-b645-3598a51c7f63} executeQuery: Code: 344. DB::Exception: Natural language processing function 'synonyms' is experimental. Set `allow_experimental_nlp_functions` setting to enable it. (SUPPORT_IS_DISABLED) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT synonyms(NULL, NULL);) 2025.09.09 15:09:54.206374 [ 20345 ] {d22d8902-5f62-49ba-b645-3598a51c7f63} TCPHandler: Code: 344. DB::Exception: Natural language processing function 'synonyms' is experimental. Set `allow_experimental_nlp_functions` setting to enable it. (SUPPORT_IS_DISABLED) 2025.09.09 15:09:54.366526 [ 20345 ] {5efe5d57-c2fd-455c-8586-034788208f88} executeQuery: Code: 42. DB::Exception: Number of arguments for function tan doesn't match: passed 2, should be 1: In scope SELECT tan(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT tan(NULL, NULL);) 2025.09.09 15:09:54.368718 [ 20345 ] {5efe5d57-c2fd-455c-8586-034788208f88} TCPHandler: Code: 42. DB::Exception: Number of arguments for function tan doesn't match: passed 2, should be 1: In scope SELECT tan(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:09:54.385777 [ 3162 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:09:54.449317 [ 20345 ] {36d93fe7-6b91-4ac3-af33-2291f673f230} executeQuery: Code: 42. DB::Exception: Number of arguments for function tanh doesn't match: passed 2, should be 1: In scope SELECT tanh(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT tanh(NULL, NULL);) 2025.09.09 15:09:54.452459 [ 20345 ] {36d93fe7-6b91-4ac3-af33-2291f673f230} TCPHandler: Code: 42. DB::Exception: Number of arguments for function tanh doesn't match: passed 2, should be 1: In scope SELECT tanh(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:09:54.501902 [ 20345 ] {672d5b71-462c-4dca-a387-e5be2b7244f9} executeQuery: Code: 42. DB::Exception: Number of arguments for function tcpPort doesn't match: passed 2, should be 0: In scope SELECT tcpPort(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT tcpPort(NULL, NULL);) 2025.09.09 15:09:54.504958 [ 20345 ] {672d5b71-462c-4dca-a387-e5be2b7244f9} TCPHandler: Code: 42. DB::Exception: Number of arguments for function tcpPort doesn't match: passed 2, should be 0: In scope SELECT tcpPort(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:09:54.654031 [ 20345 ] {bf4c0a0d-0dd2-46ac-a76e-73f6b2af7bc9} executeQuery: Code: 70. DB::Exception: Cannot convert NULL to a non-nullable type: In scope SELECT test_function(NULL, NULL). (CANNOT_CONVERT_TYPE) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT test_function(NULL, NULL);) 2025.09.09 15:09:54.667722 [ 20345 ] {bf4c0a0d-0dd2-46ac-a76e-73f6b2af7bc9} TCPHandler: Code: 70. DB::Exception: Cannot convert NULL to a non-nullable type: In scope SELECT test_function(NULL, NULL). (CANNOT_CONVERT_TYPE) 2025.09.09 15:09:54.702776 [ 3179 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:09:54.704226 [ 3204 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:09:54.733222 [ 20345 ] {fdba324b-bc2c-4957-a399-230d1025d9fb} executeQuery: Code: 42. DB::Exception: Number of arguments for function tgamma doesn't match: passed 2, should be 1: In scope SELECT tgamma(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT tgamma(NULL, NULL);) 2025.09.09 15:09:54.737163 [ 20345 ] {fdba324b-bc2c-4957-a399-230d1025d9fb} TCPHandler: Code: 42. DB::Exception: Number of arguments for function tgamma doesn't match: passed 2, should be 1: In scope SELECT tgamma(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:09:55.122206 [ 20345 ] {c45a9604-3821-4d02-82f1-7eb46216b2a5} executeQuery: Code: 42. DB::Exception: Number of arguments for function tid doesn't match: passed 2, should be 0: In scope SELECT tid(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT tid(NULL, NULL);) 2025.09.09 15:09:55.127435 [ 20345 ] {c45a9604-3821-4d02-82f1-7eb46216b2a5} TCPHandler: Code: 42. DB::Exception: Number of arguments for function tid doesn't match: passed 2, should be 0: In scope SELECT tid(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:09:55.191898 [ 2757 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:09:55.387763 [ 3220 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:09:55.470526 [ 20345 ] {654b20dd-3ce1-4c74-9787-58c07be67872} executeQuery: Code: 42. DB::Exception: Number of arguments for function timezone doesn't match: passed 2, should be 0: In scope SELECT timeZone(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT timeZone(NULL, NULL);) 2025.09.09 15:09:55.474434 [ 20345 ] {654b20dd-3ce1-4c74-9787-58c07be67872} TCPHandler: Code: 42. DB::Exception: Number of arguments for function timezone doesn't match: passed 2, should be 0: In scope SELECT timeZone(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:09:55.499113 [ 20345 ] {225710e2-fa59-4860-b06f-6154a226bc2b} executeQuery: Code: 42. DB::Exception: Number of arguments for function timezoneOf doesn't match: passed 2, should be 1: In scope SELECT timeZoneOf(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT timeZoneOf(NULL, NULL);) 2025.09.09 15:09:55.501482 [ 20345 ] {225710e2-fa59-4860-b06f-6154a226bc2b} TCPHandler: Code: 42. DB::Exception: Number of arguments for function timezoneOf doesn't match: passed 2, should be 1: In scope SELECT timeZoneOf(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:09:55.704955 [ 2778 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:09:55.711845 [ 2772 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:09:55.945592 [ 20345 ] {b3de2270-44c7-44dd-aaeb-a7dc77dd4517} executeQuery: Code: 42. DB::Exception: Number of arguments for function timezone doesn't match: passed 2, should be 0: In scope SELECT timezone(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT timezone(NULL, NULL);) 2025.09.09 15:09:55.950125 [ 20345 ] {b3de2270-44c7-44dd-aaeb-a7dc77dd4517} TCPHandler: Code: 42. DB::Exception: Number of arguments for function timezone doesn't match: passed 2, should be 0: In scope SELECT timezone(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:09:56.020733 [ 20345 ] {cf4e2683-3c82-4791-b0e3-de61d9b1d062} executeQuery: Code: 42. DB::Exception: Number of arguments for function timezoneOf doesn't match: passed 2, should be 1: In scope SELECT timezoneOf(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT timezoneOf(NULL, NULL);) 2025.09.09 15:09:56.023182 [ 20345 ] {cf4e2683-3c82-4791-b0e3-de61d9b1d062} TCPHandler: Code: 42. DB::Exception: Number of arguments for function timezoneOf doesn't match: passed 2, should be 1: In scope SELECT timezoneOf(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:09:56.067345 [ 20345 ] {2f654302-fc67-496a-87fc-d175886b087f} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=790, jobs=745). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT timezoneOffset(NULL, NULL);) 2025.09.09 15:09:56.069985 [ 20345 ] {2f654302-fc67-496a-87fc-d175886b087f} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=790, jobs=745). (CANNOT_SCHEDULE_TASK) 2025.09.09 15:09:56.121678 [ 20345 ] {d7917a55-f688-4fa6-aaab-4df7edba6ca4} executeQuery: Code: 42. DB::Exception: Number of arguments for function toBool doesn't match: passed 2, should be 1: In scope SELECT toBool(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT toBool(NULL, NULL);) 2025.09.09 15:09:56.124994 [ 20345 ] {d7917a55-f688-4fa6-aaab-4df7edba6ca4} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toBool doesn't match: passed 2, should be 1: In scope SELECT toBool(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:09:56.194460 [ 2777 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:09:56.248999 [ 20345 ] {65aaf616-e327-4ec9-99ff-f2d3511fc013} executeQuery: Code: 42. DB::Exception: Number of arguments for function toColumnTypeName doesn't match: passed 2, should be 1: In scope SELECT toColumnTypeName(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT toColumnTypeName(NULL, NULL);) 2025.09.09 15:09:56.262831 [ 20345 ] {65aaf616-e327-4ec9-99ff-f2d3511fc013} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toColumnTypeName doesn't match: passed 2, should be 1: In scope SELECT toColumnTypeName(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:09:56.391157 [ 2799 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:09:56.614722 [ 20345 ] {5ae159f7-c7a2-4f9a-8e4d-c5cfe64ee021} executeQuery: Code: 36. DB::Exception: Default value type should be same as cast type. Expected Date32. Actual Nullable(Nothing): In scope SELECT toDate32OrDefault(NULL, NULL). (BAD_ARGUMENTS) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT toDate32OrDefault(NULL, NULL);) 2025.09.09 15:09:56.621519 [ 20345 ] {5ae159f7-c7a2-4f9a-8e4d-c5cfe64ee021} TCPHandler: Code: 36. DB::Exception: Default value type should be same as cast type. Expected Date32. Actual Nullable(Nothing): In scope SELECT toDate32OrDefault(NULL, NULL). (BAD_ARGUMENTS) 2025.09.09 15:09:56.708236 [ 2876 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:09:56.714761 [ 2877 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:09:56.927431 [ 20345 ] {4f33ec4e-f80a-4add-9529-4220ac47c2e5} executeQuery: Code: 36. DB::Exception: Default value type should be same as cast type. Expected Date. Actual Nullable(Nothing): In scope SELECT toDateOrDefault(NULL, NULL). (BAD_ARGUMENTS) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT toDateOrDefault(NULL, NULL);) 2025.09.09 15:09:56.935257 [ 20345 ] {4f33ec4e-f80a-4add-9529-4220ac47c2e5} TCPHandler: Code: 36. DB::Exception: Default value type should be same as cast type. Expected Date. Actual Nullable(Nothing): In scope SELECT toDateOrDefault(NULL, NULL). (BAD_ARGUMENTS) 2025.09.09 15:09:57.109901 [ 20345 ] {50e37224-e562-4650-adff-e8fc65130faf} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=790, jobs=745). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT toDateOrZero(NULL, NULL);) 2025.09.09 15:09:57.118558 [ 20345 ] {50e37224-e562-4650-adff-e8fc65130faf} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=790, jobs=745). (CANNOT_SCHEDULE_TASK) 2025.09.09 15:09:57.198263 [ 2866 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:09:57.393286 [ 2873 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:09:57.514808 [ 20345 ] {0074382b-8078-47b7-b8be-f83fe354791e} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 2nd argument 'scale' to function 'toDateTime64OrDefault'. Expected: const Integer, got: Nullable(Nothing): In scope SELECT toDateTime64OrDefault(NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT toDateTime64OrDefault(NULL, NULL);) 2025.09.09 15:09:57.518907 [ 20345 ] {0074382b-8078-47b7-b8be-f83fe354791e} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 2nd argument 'scale' to function 'toDateTime64OrDefault'. Expected: const Integer, got: Nullable(Nothing): In scope SELECT toDateTime64OrDefault(NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.09.09 15:09:57.710418 [ 2915 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:09:57.717058 [ 2881 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:09:57.973235 [ 20345 ] {95572c18-5384-4472-a421-b14d78246423} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 2nd argument 'timezone' to function 'toDateTimeOrDefault'. Expected: const String, got: Nullable(Nothing): In scope SELECT toDateTimeOrDefault(NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT toDateTimeOrDefault(NULL, NULL);) 2025.09.09 15:09:57.980145 [ 20345 ] {95572c18-5384-4472-a421-b14d78246423} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 2nd argument 'timezone' to function 'toDateTimeOrDefault'. Expected: const String, got: Nullable(Nothing): In scope SELECT toDateTimeOrDefault(NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.09.09 15:09:58.201650 [ 2971 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:09:58.398648 [ 3021 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:09:58.712922 [ 2967 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:09:58.723766 [ 2991 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:09:59.205200 [ 3007 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:09:59.400990 [ 3045 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:09:59.461018 [ 20345 ] {ba36b023-e88b-474d-be20-be58bc902e88} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 2nd argument 'scale' to function 'toDecimal128OrDefault'. Expected: const Integer, got: Nullable(Nothing): In scope SELECT toDecimal128OrDefault(NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT toDecimal128OrDefault(NULL, NULL);) 2025.09.09 15:09:59.466019 [ 20345 ] {ba36b023-e88b-474d-be20-be58bc902e88} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 2nd argument 'scale' to function 'toDecimal128OrDefault'. Expected: const Integer, got: Nullable(Nothing): In scope SELECT toDecimal128OrDefault(NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.09.09 15:09:59.715664 [ 3089 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:09:59.726588 [ 3079 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:09:59.878833 [ 20345 ] {8b964a78-17be-4676-98fb-92e42cfe3eba} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 2nd argument 'scale' to function 'toDecimal256OrDefault'. Expected: const Integer, got: Nullable(Nothing): In scope SELECT toDecimal256OrDefault(NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT toDecimal256OrDefault(NULL, NULL);) 2025.09.09 15:09:59.889236 [ 20345 ] {8b964a78-17be-4676-98fb-92e42cfe3eba} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 2nd argument 'scale' to function 'toDecimal256OrDefault'. Expected: const Integer, got: Nullable(Nothing): In scope SELECT toDecimal256OrDefault(NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.09.09 15:10:00.207385 [ 3134 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:10:00.403338 [ 3151 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:10:00.459117 [ 20345 ] {96e7b951-b386-46dd-9f1c-eabded4f3866} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 2nd argument 'scale' to function 'toDecimal32OrDefault'. Expected: const Integer, got: Nullable(Nothing): In scope SELECT toDecimal32OrDefault(NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT toDecimal32OrDefault(NULL, NULL);) 2025.09.09 15:10:00.466865 [ 20345 ] {96e7b951-b386-46dd-9f1c-eabded4f3866} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 2nd argument 'scale' to function 'toDecimal32OrDefault'. Expected: const Integer, got: Nullable(Nothing): In scope SELECT toDecimal32OrDefault(NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.09.09 15:10:00.718141 [ 3177 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:10:00.776286 [ 3175 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:10:00.863695 [ 20345 ] {38c89e39-c9ce-4f3f-99cd-5d33fc314011} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 2nd argument 'scale' to function 'toDecimal64OrDefault'. Expected: const Integer, got: Nullable(Nothing): In scope SELECT toDecimal64OrDefault(NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT toDecimal64OrDefault(NULL, NULL);) 2025.09.09 15:10:00.867554 [ 20345 ] {38c89e39-c9ce-4f3f-99cd-5d33fc314011} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 2nd argument 'scale' to function 'toDecimal64OrDefault'. Expected: const Integer, got: Nullable(Nothing): In scope SELECT toDecimal64OrDefault(NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.09.09 15:10:01.209190 [ 3220 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:10:01.405666 [ 2758 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:10:01.468218 [ 20345 ] {55f04637-45a2-41ab-884a-e92b8a441ffd} executeQuery: Code: 36. DB::Exception: Default value type should be same as cast type. Expected Float32. Actual Nullable(Nothing): In scope SELECT toFloat32OrDefault(NULL, NULL). (BAD_ARGUMENTS) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT toFloat32OrDefault(NULL, NULL);) 2025.09.09 15:10:01.474710 [ 20345 ] {55f04637-45a2-41ab-884a-e92b8a441ffd} TCPHandler: Code: 36. DB::Exception: Default value type should be same as cast type. Expected Float32. Actual Nullable(Nothing): In scope SELECT toFloat32OrDefault(NULL, NULL). (BAD_ARGUMENTS) 2025.09.09 15:10:01.720946 [ 3205 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:10:01.779202 [ 3236 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:10:01.793459 [ 20345 ] {bcac4b75-a4ae-4559-a6df-ac6770c7bd8d} executeQuery: Code: 36. DB::Exception: Default value type should be same as cast type. Expected Float64. Actual Nullable(Nothing): In scope SELECT toFloat64OrDefault(NULL, NULL). (BAD_ARGUMENTS) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT toFloat64OrDefault(NULL, NULL);) 2025.09.09 15:10:01.810330 [ 20345 ] {bcac4b75-a4ae-4559-a6df-ac6770c7bd8d} TCPHandler: Code: 36. DB::Exception: Default value type should be same as cast type. Expected Float64. Actual Nullable(Nothing): In scope SELECT toFloat64OrDefault(NULL, NULL). (BAD_ARGUMENTS) 2025.09.09 15:10:02.210758 [ 2810 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:10:02.286112 [ 20345 ] {d60d2982-1c5f-41b6-ba33-9ce2c275c8c0} executeQuery: Code: 36. DB::Exception: Default value type should be same as cast type. Expected IPv4. Actual Nullable(Nothing): In scope SELECT toIPv4OrDefault(NULL, NULL). (BAD_ARGUMENTS) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT toIPv4OrDefault(NULL, NULL);) 2025.09.09 15:10:02.290172 [ 20345 ] {d60d2982-1c5f-41b6-ba33-9ce2c275c8c0} TCPHandler: Code: 36. DB::Exception: Default value type should be same as cast type. Expected IPv4. Actual Nullable(Nothing): In scope SELECT toIPv4OrDefault(NULL, NULL). (BAD_ARGUMENTS) 2025.09.09 15:10:02.407478 [ 2882 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:10:02.722902 [ 2935 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:10:02.724013 [ 20345 ] {a2e34aa1-2ae7-4a57-939e-41dbe0144293} executeQuery: Code: 36. DB::Exception: Default value type should be same as cast type. Expected IPv6. Actual Nullable(Nothing): In scope SELECT toIPv6OrDefault(NULL, NULL). (BAD_ARGUMENTS) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT toIPv6OrDefault(NULL, NULL);) 2025.09.09 15:10:02.734417 [ 20345 ] {a2e34aa1-2ae7-4a57-939e-41dbe0144293} TCPHandler: Code: 36. DB::Exception: Default value type should be same as cast type. Expected IPv6. Actual Nullable(Nothing): In scope SELECT toIPv6OrDefault(NULL, NULL). (BAD_ARGUMENTS) 2025.09.09 15:10:02.782382 [ 2887 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:10:03.212658 [ 2859 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:10:03.409505 [ 2954 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:10:03.503630 [ 20345 ] {749aa587-fa9f-4f13-ae24-b4116b8d5999} executeQuery: Code: 36. DB::Exception: Default value type should be same as cast type. Expected Int128. Actual Nullable(Nothing): In scope SELECT toInt128OrDefault(NULL, NULL). (BAD_ARGUMENTS) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT toInt128OrDefault(NULL, NULL);) 2025.09.09 15:10:03.507992 [ 20345 ] {749aa587-fa9f-4f13-ae24-b4116b8d5999} TCPHandler: Code: 36. DB::Exception: Default value type should be same as cast type. Expected Int128. Actual Nullable(Nothing): In scope SELECT toInt128OrDefault(NULL, NULL). (BAD_ARGUMENTS) 2025.09.09 15:10:03.724585 [ 2972 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:10:03.793827 [ 2985 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:10:03.890700 [ 20345 ] {b61e2f4a-18f8-4ce3-ae6d-a47e7fe82f52} executeQuery: Code: 36. DB::Exception: Default value type should be same as cast type. Expected Int16. Actual Nullable(Nothing): In scope SELECT toInt16OrDefault(NULL, NULL). (BAD_ARGUMENTS) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT toInt16OrDefault(NULL, NULL);) 2025.09.09 15:10:03.898114 [ 20345 ] {b61e2f4a-18f8-4ce3-ae6d-a47e7fe82f52} TCPHandler: Code: 36. DB::Exception: Default value type should be same as cast type. Expected Int16. Actual Nullable(Nothing): In scope SELECT toInt16OrDefault(NULL, NULL). (BAD_ARGUMENTS) 2025.09.09 15:10:04.214791 [ 3001 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:10:04.357557 [ 20345 ] {7a50ec17-c039-48f0-b48b-4beb83055fec} executeQuery: Code: 36. DB::Exception: Default value type should be same as cast type. Expected Int256. Actual Nullable(Nothing): In scope SELECT toInt256OrDefault(NULL, NULL). (BAD_ARGUMENTS) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT toInt256OrDefault(NULL, NULL);) 2025.09.09 15:10:04.362507 [ 20345 ] {7a50ec17-c039-48f0-b48b-4beb83055fec} TCPHandler: Code: 36. DB::Exception: Default value type should be same as cast type. Expected Int256. Actual Nullable(Nothing): In scope SELECT toInt256OrDefault(NULL, NULL). (BAD_ARGUMENTS) 2025.09.09 15:10:04.411829 [ 3053 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:10:04.727594 [ 3090 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:10:04.765795 [ 20345 ] {d67d386b-6f67-47e3-baf9-51261bd4a32d} executeQuery: Code: 36. DB::Exception: Default value type should be same as cast type. Expected Int32. Actual Nullable(Nothing): In scope SELECT toInt32OrDefault(NULL, NULL). (BAD_ARGUMENTS) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT toInt32OrDefault(NULL, NULL);) 2025.09.09 15:10:04.776144 [ 20345 ] {d67d386b-6f67-47e3-baf9-51261bd4a32d} TCPHandler: Code: 36. DB::Exception: Default value type should be same as cast type. Expected Int32. Actual Nullable(Nothing): In scope SELECT toInt32OrDefault(NULL, NULL). (BAD_ARGUMENTS) 2025.09.09 15:10:04.796596 [ 3018 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:10:05.217478 [ 3111 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:10:05.229092 [ 20345 ] {bfc6e610-87a2-4af0-b1ec-09d493af7b42} executeQuery: Code: 36. DB::Exception: Default value type should be same as cast type. Expected Int64. Actual Nullable(Nothing): In scope SELECT toInt64OrDefault(NULL, NULL). (BAD_ARGUMENTS) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT toInt64OrDefault(NULL, NULL);) 2025.09.09 15:10:05.232016 [ 20345 ] {bfc6e610-87a2-4af0-b1ec-09d493af7b42} TCPHandler: Code: 36. DB::Exception: Default value type should be same as cast type. Expected Int64. Actual Nullable(Nothing): In scope SELECT toInt64OrDefault(NULL, NULL). (BAD_ARGUMENTS) 2025.09.09 15:10:05.429223 [ 3131 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:10:05.617585 [ 20345 ] {e94c5c01-1faf-4918-aa20-d61d240792fc} executeQuery: Code: 36. DB::Exception: Default value type should be same as cast type. Expected Int8. Actual Nullable(Nothing): In scope SELECT toInt8OrDefault(NULL, NULL). (BAD_ARGUMENTS) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT toInt8OrDefault(NULL, NULL);) 2025.09.09 15:10:05.634541 [ 20345 ] {e94c5c01-1faf-4918-aa20-d61d240792fc} TCPHandler: Code: 36. DB::Exception: Default value type should be same as cast type. Expected Int8. Actual Nullable(Nothing): In scope SELECT toInt8OrDefault(NULL, NULL). (BAD_ARGUMENTS) 2025.09.09 15:10:05.730814 [ 3133 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:10:05.800246 [ 3145 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:10:06.219483 [ 3156 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:10:06.431340 [ 3228 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:10:06.733131 [ 2767 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:10:06.802882 [ 2773 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:10:07.223299 [ 2741 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:10:07.226002 [ 20345 ] {a0a0f30b-3541-49a4-8b85-c9f0a91a8df8} executeQuery: Code: 42. DB::Exception: Number of arguments for function toJSONString doesn't match: passed 2, should be 1: In scope SELECT toJSONString(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT toJSONString(NULL, NULL);) 2025.09.09 15:10:07.231432 [ 20345 ] {a0a0f30b-3541-49a4-8b85-c9f0a91a8df8} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toJSONString doesn't match: passed 2, should be 1: In scope SELECT toJSONString(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:10:07.433178 [ 2810 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:10:07.449188 [ 20345 ] {d476c931-9fde-4648-8e24-c46f13a28352} executeQuery: Code: 42. DB::Exception: Number of arguments for function toLowCardinality doesn't match: passed 2, should be 1: In scope SELECT toLowCardinality(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT toLowCardinality(NULL, NULL);) 2025.09.09 15:10:07.456556 [ 20345 ] {d476c931-9fde-4648-8e24-c46f13a28352} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toLowCardinality doesn't match: passed 2, should be 1: In scope SELECT toLowCardinality(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:10:07.735694 [ 2917 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:10:07.805740 [ 2844 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:10:07.922460 [ 20345 ] {e2ba15c1-802c-46ae-9d3c-28a68e10531d} executeQuery: Code: 42. DB::Exception: Number of arguments for function toModifiedJulianDay doesn't match: passed 2, should be 1: In scope SELECT toModifiedJulianDay(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT toModifiedJulianDay(NULL, NULL);) 2025.09.09 15:10:07.929179 [ 20345 ] {e2ba15c1-802c-46ae-9d3c-28a68e10531d} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toModifiedJulianDay doesn't match: passed 2, should be 1: In scope SELECT toModifiedJulianDay(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:10:08.038970 [ 20345 ] {40097d12-d3bd-4adb-a330-3380fb0b2f55} executeQuery: Code: 42. DB::Exception: Number of arguments for function toModifiedJulianDayOrNull doesn't match: passed 2, should be 1: In scope SELECT toModifiedJulianDayOrNull(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT toModifiedJulianDayOrNull(NULL, NULL);) 2025.09.09 15:10:08.046880 [ 20345 ] {40097d12-d3bd-4adb-a330-3380fb0b2f55} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toModifiedJulianDayOrNull doesn't match: passed 2, should be 1: In scope SELECT toModifiedJulianDayOrNull(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:10:08.225875 [ 2907 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:10:08.435692 [ 2925 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:10:08.440166 [ 20345 ] {371eeaf7-5777-4a74-bfbb-f889c8e5c00e} executeQuery: Code: 42. DB::Exception: Number of arguments for function toNullable doesn't match: passed 2, should be 1: In scope SELECT toNullable(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT toNullable(NULL, NULL);) 2025.09.09 15:10:08.444516 [ 20345 ] {371eeaf7-5777-4a74-bfbb-f889c8e5c00e} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toNullable doesn't match: passed 2, should be 1: In scope SELECT toNullable(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:10:08.739009 [ 2902 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:10:08.809075 [ 2940 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:10:08.876911 [ 20379 ] {059a771f-98e2-4ed9-bf77-c88f39ed3262} 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.10505.altinitytest (altinity build)) (from [::1]:58504) (comment: 01518_nullable_aggregate_states2.sql) (in query: SELECT id, count(), minMerge(stringMin), maxMerge(stringMax), floor(minMerge(float64Min),5), floor(maxMerge(float64Max),5), floor(avgMerge(float64Avg),5), floor(sumMerge(float64Sum),5), floor(minMerge(float32Min),5), floor(maxMerge(float32Max),5), floor(avgMerge(float32Avg),5), floor(sumMerge(float32Sum),5), minMerge(decimal325Min), maxMerge(decimal325Max), avgMerge(decimal325Avg), sumMerge(decimal325Sum), minMerge(dateMin), maxMerge(dateMax), minMerge(datetimeMin), maxMerge(datetimeMax), minMerge(datetime64Min), maxMerge(datetime64Max), minMerge(int64Min), maxMerge(int64Max), avgMerge(int64Avg), sumMerge(int64Sum), minMerge(int32Min), maxMerge(int32Max), avgMerge(int32Avg), sumMerge(int32Sum), minMerge(int16Min), maxMerge(int16Max), avgMerge(int16Avg), sumMerge(int16Sum), minMerge(int8Min), maxMerge(int8Max), avgMerge(int8Avg), sumMerge(int8Sum) FROM testNullableStatesAgg GROUP BY id ORDER BY id ASC;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af819ed 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af82f33 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002c64fc80 7. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1723: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr, unsigned long, std::shared_ptr, std::equal_to, std::allocator>>>, DB::MergeTreeData const&, std::vector> const&, std::shared_ptr, std::optional&, bool) @ 0x000000002de379fd 8. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1437: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000002de3554f 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:0: DB::ReadFromMergeTree::getAnalysisResult() const @ 0x000000002de41345 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:2022: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000002de4404c 11. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000002ddb933c 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000002ddff11e 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000002942117f 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x00000000294209e7 15. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b382fc 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 18. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 22. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:10:08.882547 [ 20379 ] {059a771f-98e2-4ed9-bf77-c88f39ed3262} 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af819ed 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af82f33 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002c64fc80 7. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1723: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr, unsigned long, std::shared_ptr, std::equal_to, std::allocator>>>, DB::MergeTreeData const&, std::vector> const&, std::shared_ptr, std::optional&, bool) @ 0x000000002de379fd 8. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1437: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000002de3554f 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:0: DB::ReadFromMergeTree::getAnalysisResult() const @ 0x000000002de41345 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:2022: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000002de4404c 11. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000002ddb933c 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000002ddff11e 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000002942117f 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x00000000294209e7 15. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b382fc 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 18. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 22. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:10:09.229033 [ 2948 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:10:09.345103 [ 20380 ] {7e73912f-1354-4057-b576-6f0a1d90b0db} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:38658) (comment: 01518_nullable_aggregate_states2.sql) (in query: DROP DATABASE IF EXISTS test_tpzjawdv ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aac868e 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x00000000286b57c7 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x00000000291f5630 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:361: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000291edc97 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x00000000291ebf11 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x00000000291eb7ed 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b382fc 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1529: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000029b3ed3f 11. ./build_docker/./src/Server/HTTPHandler.cpp:529: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000002d0662d1 12. ./build_docker/./src/Server/HTTPHandler.cpp:705: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000002d06d139 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000002d1cc337 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 18. asan_thread_start(void*) @ 0x000000000aa43059 19. ? @ 0x00007f35aab92ac3 20. ? @ 0x00007f35aac24850 2025.09.09 15:10:09.348287 [ 20380 ] {7e73912f-1354-4057-b576-6f0a1d90b0db} DynamicQueryHandler: Code: 219. DB::Exception: New table 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aac868e 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x00000000286b57c7 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x00000000291f5630 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:361: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000291edc97 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x00000000291ebf11 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x00000000291eb7ed 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b382fc 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1529: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000029b3ed3f 11. ./build_docker/./src/Server/HTTPHandler.cpp:529: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000002d0662d1 12. ./build_docker/./src/Server/HTTPHandler.cpp:705: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000002d06d139 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000002d1cc337 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 18. asan_thread_start(void*) @ 0x000000000aa43059 19. ? @ 0x00007f35aab92ac3 20. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:10:09.439022 [ 2972 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:10:09.741775 [ 2982 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:10:09.812101 [ 3014 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:10:10.231638 [ 3039 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:10:10.453777 [ 3077 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:10:10.743934 [ 3085 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:10:10.814579 [ 3084 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:10:11.233878 [ 3136 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:10:11.456417 [ 3097 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:10:11.745874 [ 3174 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:10:11.816537 [ 3233 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:10:12.028829 [ 20345 ] {c41d8c1d-46ea-40f2-9817-0a06efa49522} executeQuery: Code: 42. DB::Exception: Number of arguments for function toStringCutToZero doesn't match: passed 2, should be 1: In scope SELECT toStringCutToZero(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT toStringCutToZero(NULL, NULL);) 2025.09.09 15:10:12.072497 [ 20345 ] {c41d8c1d-46ea-40f2-9817-0a06efa49522} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toStringCutToZero doesn't match: passed 2, should be 1: In scope SELECT toStringCutToZero(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:10:12.242594 [ 3224 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:10:12.459179 [ 3242 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:10:12.555074 [ 20345 ] {2e035401-a010-4511-b816-3a08a3a5262c} executeQuery: Code: 42. DB::Exception: Number of arguments for function toTypeName doesn't match: passed 2, should be 1: In scope SELECT toTypeName(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT toTypeName(NULL, NULL);) 2025.09.09 15:10:12.559934 [ 20345 ] {2e035401-a010-4511-b816-3a08a3a5262c} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toTypeName doesn't match: passed 2, should be 1: In scope SELECT toTypeName(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:10:12.748448 [ 2778 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:10:12.785314 [ 20345 ] {13840862-400c-42b2-8216-94b5dccc45d1} executeQuery: Code: 36. DB::Exception: Default value type should be same as cast type. Expected UInt128. Actual Nullable(Nothing): In scope SELECT toUInt128OrDefault(NULL, NULL). (BAD_ARGUMENTS) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT toUInt128OrDefault(NULL, NULL);) 2025.09.09 15:10:12.789632 [ 20345 ] {13840862-400c-42b2-8216-94b5dccc45d1} TCPHandler: Code: 36. DB::Exception: Default value type should be same as cast type. Expected UInt128. Actual Nullable(Nothing): In scope SELECT toUInt128OrDefault(NULL, NULL). (BAD_ARGUMENTS) 2025.09.09 15:10:12.819283 [ 3159 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:10:13.244515 [ 2796 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:10:13.385510 [ 20345 ] {68b7bbea-7602-478a-bfb8-257a0a8ddf8b} executeQuery: Code: 36. DB::Exception: Default value type should be same as cast type. Expected UInt16. Actual Nullable(Nothing): In scope SELECT toUInt16OrDefault(NULL, NULL). (BAD_ARGUMENTS) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT toUInt16OrDefault(NULL, NULL);) 2025.09.09 15:10:13.389546 [ 20345 ] {68b7bbea-7602-478a-bfb8-257a0a8ddf8b} TCPHandler: Code: 36. DB::Exception: Default value type should be same as cast type. Expected UInt16. Actual Nullable(Nothing): In scope SELECT toUInt16OrDefault(NULL, NULL). (BAD_ARGUMENTS) 2025.09.09 15:10:13.463403 [ 2786 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:10:13.750718 [ 2865 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:10:13.821949 [ 2829 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:10:14.045184 [ 20345 ] {d0a2f15a-f953-48e7-8e7a-af5f34c00f02} executeQuery: Code: 36. DB::Exception: Default value type should be same as cast type. Expected UInt256. Actual Nullable(Nothing): In scope SELECT toUInt256OrDefault(NULL, NULL). (BAD_ARGUMENTS) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT toUInt256OrDefault(NULL, NULL);) 2025.09.09 15:10:14.056405 [ 20345 ] {d0a2f15a-f953-48e7-8e7a-af5f34c00f02} TCPHandler: Code: 36. DB::Exception: Default value type should be same as cast type. Expected UInt256. Actual Nullable(Nothing): In scope SELECT toUInt256OrDefault(NULL, NULL). (BAD_ARGUMENTS) 2025.09.09 15:10:14.246788 [ 2910 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:10:14.465817 [ 2823 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:10:14.579920 [ 20345 ] {49bfac0a-d212-4280-b7d6-d897d094804a} executeQuery: Code: 36. DB::Exception: Default value type should be same as cast type. Expected UInt32. Actual Nullable(Nothing): In scope SELECT toUInt32OrDefault(NULL, NULL). (BAD_ARGUMENTS) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT toUInt32OrDefault(NULL, NULL);) 2025.09.09 15:10:14.586332 [ 20345 ] {49bfac0a-d212-4280-b7d6-d897d094804a} TCPHandler: Code: 36. DB::Exception: Default value type should be same as cast type. Expected UInt32. Actual Nullable(Nothing): In scope SELECT toUInt32OrDefault(NULL, NULL). (BAD_ARGUMENTS) 2025.09.09 15:10:14.756535 [ 2873 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:10:14.823936 [ 2919 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:10:15.106686 [ 20345 ] {67fd8317-2833-4158-9541-ae200c6fd52d} executeQuery: Code: 36. DB::Exception: Default value type should be same as cast type. Expected UInt64. Actual Nullable(Nothing): In scope SELECT toUInt64OrDefault(NULL, NULL). (BAD_ARGUMENTS) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT toUInt64OrDefault(NULL, NULL);) 2025.09.09 15:10:15.114775 [ 20345 ] {67fd8317-2833-4158-9541-ae200c6fd52d} TCPHandler: Code: 36. DB::Exception: Default value type should be same as cast type. Expected UInt64. Actual Nullable(Nothing): In scope SELECT toUInt64OrDefault(NULL, NULL). (BAD_ARGUMENTS) 2025.09.09 15:10:15.248847 [ 2835 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:10:15.468895 [ 2952 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:10:15.689283 [ 20345 ] {dc866f35-d2b9-4f5b-b362-971d8f0bff89} executeQuery: Code: 36. DB::Exception: Default value type should be same as cast type. Expected UInt8. Actual Nullable(Nothing): In scope SELECT toUInt8OrDefault(NULL, NULL). (BAD_ARGUMENTS) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT toUInt8OrDefault(NULL, NULL);) 2025.09.09 15:10:15.698773 [ 20345 ] {dc866f35-d2b9-4f5b-b362-971d8f0bff89} TCPHandler: Code: 36. DB::Exception: Default value type should be same as cast type. Expected UInt8. Actual Nullable(Nothing): In scope SELECT toUInt8OrDefault(NULL, NULL). (BAD_ARGUMENTS) 2025.09.09 15:10:15.767216 [ 2984 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:10:15.826753 [ 2981 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:10:16.250984 [ 3015 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:10:16.397224 [ 20345 ] {9b38cccf-dca2-413b-a95d-e4fa1d99f4ed} executeQuery: Code: 36. DB::Exception: Default value type should be same as cast type. Expected UUID. Actual Nullable(Nothing): In scope SELECT toUUIDOrDefault(NULL, NULL). (BAD_ARGUMENTS) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT toUUIDOrDefault(NULL, NULL);) 2025.09.09 15:10:16.402126 [ 20345 ] {9b38cccf-dca2-413b-a95d-e4fa1d99f4ed} TCPHandler: Code: 36. DB::Exception: Default value type should be same as cast type. Expected UUID. Actual Nullable(Nothing): In scope SELECT toUUIDOrDefault(NULL, NULL). (BAD_ARGUMENTS) 2025.09.09 15:10:16.471297 [ 2996 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:10:16.769463 [ 3048 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:10:16.819948 [ 20345 ] {8d889f0d-e801-439d-bd15-9c069682d8ab} executeQuery: Code: 42. DB::Exception: Number of arguments for function toUnixTimestamp64Micro doesn't match: passed 2, should be 1: In scope SELECT toUnixTimestamp64Micro(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT toUnixTimestamp64Micro(NULL, NULL);) 2025.09.09 15:10:16.823634 [ 20345 ] {8d889f0d-e801-439d-bd15-9c069682d8ab} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toUnixTimestamp64Micro doesn't match: passed 2, should be 1: In scope SELECT toUnixTimestamp64Micro(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:10:16.832617 [ 3112 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:10:16.912974 [ 20345 ] {1d32f181-e36c-48c7-a78c-7488f1dbe867} executeQuery: Code: 42. DB::Exception: Number of arguments for function toUnixTimestamp64Milli doesn't match: passed 2, should be 1: In scope SELECT toUnixTimestamp64Milli(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT toUnixTimestamp64Milli(NULL, NULL);) 2025.09.09 15:10:16.919605 [ 20345 ] {1d32f181-e36c-48c7-a78c-7488f1dbe867} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toUnixTimestamp64Milli doesn't match: passed 2, should be 1: In scope SELECT toUnixTimestamp64Milli(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:10:17.010506 [ 20345 ] {13f103e0-88dc-488f-a13c-eb2d9bd409e9} executeQuery: Code: 42. DB::Exception: Number of arguments for function toUnixTimestamp64Nano doesn't match: passed 2, should be 1: In scope SELECT toUnixTimestamp64Nano(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT toUnixTimestamp64Nano(NULL, NULL);) 2025.09.09 15:10:17.016504 [ 20345 ] {13f103e0-88dc-488f-a13c-eb2d9bd409e9} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toUnixTimestamp64Nano doesn't match: passed 2, should be 1: In scope SELECT toUnixTimestamp64Nano(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:10:17.084455 [ 3328 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {166e6d4b-ecec-41a4-ad4a-0c1c77ff9a47::202509_322_327_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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, char const*&&) @ 0x000000001adfc17a 4. ./build_docker/./src/Common/MemoryTracker.cpp:187: MemoryTracker::injectFault() const @ 0x000000001adf8d1a 5. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:0: DB::MergePlainMergeTreeTask::finish() @ 0x000000002cc30a65 6. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:0: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000002cc2f47b 7. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000002c427f28 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000002c429675 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7eaf0 10. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001af8a79f 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 13. asan_thread_start(void*) @ 0x000000000aa43059 14. ? @ 0x00007f35aab92ac3 15. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:10:17.100834 [ 20345 ] {a1522b9e-f887-49b9-b97a-d24c7187551f} executeQuery: Code: 42. DB::Exception: Number of arguments for function toValidUTF8 doesn't match: passed 2, should be 1: In scope SELECT toValidUTF8(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT toValidUTF8(NULL, NULL);) 2025.09.09 15:10:17.116052 [ 20345 ] {a1522b9e-f887-49b9-b97a-d24c7187551f} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toValidUTF8 doesn't match: passed 2, should be 1: In scope SELECT toValidUTF8(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:10:17.253934 [ 3109 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:10:17.473525 [ 3135 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:10:17.771586 [ 3133 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:10:17.834806 [ 3166 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:10:18.077313 [ 20345 ] {607bd5ae-963d-4b96-8347-f66b19ae8416} executeQuery: Code: 42. DB::Exception: Number of arguments for function today doesn't match: passed 2, should be 0: In scope SELECT today(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT today(NULL, NULL);) 2025.09.09 15:10:18.090456 [ 20345 ] {607bd5ae-963d-4b96-8347-f66b19ae8416} TCPHandler: Code: 42. DB::Exception: Number of arguments for function today doesn't match: passed 2, should be 0: In scope SELECT today(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:10:18.229741 [ 20345 ] {4bdfafa7-4d24-4a23-a7a8-0c8d3785a9b1} executeQuery: Code: 42. DB::Exception: Number of arguments for function tokens doesn't match: passed 2, should be 1: In scope SELECT tokens(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT tokens(NULL, NULL);) 2025.09.09 15:10:18.235921 [ 20345 ] {4bdfafa7-4d24-4a23-a7a8-0c8d3785a9b1} TCPHandler: Code: 42. DB::Exception: Number of arguments for function tokens doesn't match: passed 2, should be 1: In scope SELECT tokens(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:10:18.255757 [ 3197 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:10:18.475271 [ 2749 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:10:18.581570 [ 20345 ] {e4ccb18a-66f6-44a6-ba9d-9d9002490a2b} executeQuery: Code: 42. DB::Exception: Number of arguments for function topLevelDomain doesn't match: passed 2, should be 1: In scope SELECT topLevelDomain(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT topLevelDomain(NULL, NULL);) 2025.09.09 15:10:18.595332 [ 20345 ] {e4ccb18a-66f6-44a6-ba9d-9d9002490a2b} TCPHandler: Code: 42. DB::Exception: Number of arguments for function topLevelDomain doesn't match: passed 2, should be 1: In scope SELECT topLevelDomain(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:10:18.773549 [ 2765 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:10:18.821417 [ 20345 ] {36f2a366-00d4-4a51-b065-8fce06b6444e} executeQuery: Code: 42. DB::Exception: Number of arguments for function topLevelDomainRFC doesn't match: passed 2, should be 1: In scope SELECT topLevelDomainRFC(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT topLevelDomainRFC(NULL, NULL);) 2025.09.09 15:10:18.825467 [ 20345 ] {36f2a366-00d4-4a51-b065-8fce06b6444e} TCPHandler: Code: 42. DB::Exception: Number of arguments for function topLevelDomainRFC doesn't match: passed 2, should be 1: In scope SELECT topLevelDomainRFC(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:10:18.836532 [ 2763 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:10:18.889478 [ 20345 ] {f31585a8-8603-4d20-9c78-b2b9ef90241f} executeQuery: Code: 42. DB::Exception: Number of arguments for function transactionID doesn't match: passed 2, should be 0: In scope SELECT transactionID(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT transactionID(NULL, NULL);) 2025.09.09 15:10:18.896991 [ 20345 ] {f31585a8-8603-4d20-9c78-b2b9ef90241f} TCPHandler: Code: 42. DB::Exception: Number of arguments for function transactionID doesn't match: passed 2, should be 0: In scope SELECT transactionID(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:10:18.973958 [ 20345 ] {4d56cb49-19d8-4834-990d-58b974d9e24d} executeQuery: Code: 42. DB::Exception: Number of arguments for function transactionLatestSnapshot doesn't match: passed 2, should be 0: In scope SELECT transactionLatestSnapshot(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT transactionLatestSnapshot(NULL, NULL);) 2025.09.09 15:10:18.983351 [ 20345 ] {4d56cb49-19d8-4834-990d-58b974d9e24d} TCPHandler: Code: 42. DB::Exception: Number of arguments for function transactionLatestSnapshot doesn't match: passed 2, should be 0: In scope SELECT transactionLatestSnapshot(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:10:19.074509 [ 20345 ] {3b863ba3-d2c0-44a0-8082-35811fd2beac} executeQuery: Code: 42. DB::Exception: Number of arguments for function transactionOldestSnapshot doesn't match: passed 2, should be 0: In scope SELECT transactionOldestSnapshot(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT transactionOldestSnapshot(NULL, NULL);) 2025.09.09 15:10:19.084846 [ 20345 ] {3b863ba3-d2c0-44a0-8082-35811fd2beac} TCPHandler: Code: 42. DB::Exception: Number of arguments for function transactionOldestSnapshot doesn't match: passed 2, should be 0: In scope SELECT transactionOldestSnapshot(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:10:19.175938 [ 20345 ] {58498177-4bca-4a06-b65b-0cd86eab13af} executeQuery: Code: 42. DB::Exception: Number of arguments for function transform doesn't match: passed 2, should be 3 or 4: In scope SELECT transform(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT transform(NULL, NULL);) 2025.09.09 15:10:19.184938 [ 20345 ] {58498177-4bca-4a06-b65b-0cd86eab13af} TCPHandler: Code: 42. DB::Exception: Number of arguments for function transform doesn't match: passed 2, should be 3 or 4: In scope SELECT transform(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:10:19.253872 [ 20345 ] {9336a410-c42d-4c7a-b3e9-9ab43ee10d6c} executeQuery: Code: 42. DB::Exception: Number of arguments for function translate doesn't match: passed 2, should be 3: In scope SELECT translate(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT translate(NULL, NULL);) 2025.09.09 15:10:19.263390 [ 3226 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:10:19.272561 [ 20345 ] {9336a410-c42d-4c7a-b3e9-9ab43ee10d6c} TCPHandler: Code: 42. DB::Exception: Number of arguments for function translate doesn't match: passed 2, should be 3: In scope SELECT translate(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:10:19.397888 [ 20345 ] {d5a90356-91d1-4974-a1cd-2a9c42a303bb} executeQuery: Code: 42. DB::Exception: Number of arguments for function translateUTF8 doesn't match: passed 2, should be 3: In scope SELECT translateUTF8(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT translateUTF8(NULL, NULL);) 2025.09.09 15:10:19.412398 [ 20345 ] {d5a90356-91d1-4974-a1cd-2a9c42a303bb} TCPHandler: Code: 42. DB::Exception: Number of arguments for function translateUTF8 doesn't match: passed 2, should be 3: In scope SELECT translateUTF8(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:10:19.477225 [ 2777 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:10:19.477855 [ 20345 ] {2850df08-e579-4dc2-bcab-a374b8971476} executeQuery: Code: 42. DB::Exception: Number of arguments for function trimBoth doesn't match: passed 2, should be 1: In scope SELECT trimBoth(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT trimBoth(NULL, NULL);) 2025.09.09 15:10:19.483556 [ 20345 ] {2850df08-e579-4dc2-bcab-a374b8971476} TCPHandler: Code: 42. DB::Exception: Number of arguments for function trimBoth doesn't match: passed 2, should be 1: In scope SELECT trimBoth(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:10:19.586024 [ 20345 ] {0961ba3c-e2ba-4de7-8408-d3da7d64033e} executeQuery: Code: 42. DB::Exception: Number of arguments for function trimLeft doesn't match: passed 2, should be 1: In scope SELECT trimLeft(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT trimLeft(NULL, NULL);) 2025.09.09 15:10:19.591292 [ 20345 ] {0961ba3c-e2ba-4de7-8408-d3da7d64033e} TCPHandler: Code: 42. DB::Exception: Number of arguments for function trimLeft doesn't match: passed 2, should be 1: In scope SELECT trimLeft(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:10:19.769777 [ 20345 ] {935746fa-4395-4c35-8d43-8c03734dc859} executeQuery: Code: 42. DB::Exception: Number of arguments for function trimRight doesn't match: passed 2, should be 1: In scope SELECT trimRight(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT trimRight(NULL, NULL);) 2025.09.09 15:10:19.775220 [ 20345 ] {935746fa-4395-4c35-8d43-8c03734dc859} TCPHandler: Code: 42. DB::Exception: Number of arguments for function trimRight doesn't match: passed 2, should be 1: In scope SELECT trimRight(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:10:19.775778 [ 2826 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:10:19.838463 [ 2842 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:10:20.191925 [ 20345 ] {922be453-f3a3-47a1-9d48-8b5962b6b3d6} executeQuery: Code: 42. DB::Exception: Number of arguments for function tryBase58Decode doesn't match: passed 2, should be 1: In scope SELECT tryBase58Decode(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT tryBase58Decode(NULL, NULL);) 2025.09.09 15:10:20.247385 [ 20345 ] {922be453-f3a3-47a1-9d48-8b5962b6b3d6} TCPHandler: Code: 42. DB::Exception: Number of arguments for function tryBase58Decode doesn't match: passed 2, should be 1: In scope SELECT tryBase58Decode(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:10:20.265920 [ 2909 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:10:20.324220 [ 20345 ] {e4808951-2c20-4654-a0a1-b847a163e8b4} executeQuery: Code: 42. DB::Exception: Number of arguments for function tryBase64Decode doesn't match: passed 2, should be 1: In scope SELECT tryBase64Decode(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT tryBase64Decode(NULL, NULL);) 2025.09.09 15:10:20.327729 [ 20345 ] {e4808951-2c20-4654-a0a1-b847a163e8b4} TCPHandler: Code: 42. DB::Exception: Number of arguments for function tryBase64Decode doesn't match: passed 2, should be 1: In scope SELECT tryBase64Decode(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:10:20.456034 [ 20345 ] {f58d1dd0-d1e1-4bc1-9655-7fd2d84a7dbd} executeQuery: Code: 42. DB::Exception: Number of arguments for function tryBase64URLDecode doesn't match: passed 2, should be 1: In scope SELECT tryBase64URLDecode(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT tryBase64URLDecode(NULL, NULL);) 2025.09.09 15:10:20.463162 [ 20345 ] {f58d1dd0-d1e1-4bc1-9655-7fd2d84a7dbd} TCPHandler: Code: 42. DB::Exception: Number of arguments for function tryBase64URLDecode doesn't match: passed 2, should be 1: In scope SELECT tryBase64URLDecode(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:10:20.479313 [ 2822 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:10:20.648869 [ 20345 ] {e358bcbc-ea1f-417f-b610-7e2f3efa5b43} executeQuery: Code: 42. DB::Exception: Number of arguments for function tryIdnaEncode doesn't match: passed 2, should be 1: In scope SELECT tryIdnaEncode(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT tryIdnaEncode(NULL, NULL);) 2025.09.09 15:10:20.658401 [ 20345 ] {e358bcbc-ea1f-417f-b610-7e2f3efa5b43} TCPHandler: Code: 42. DB::Exception: Number of arguments for function tryIdnaEncode doesn't match: passed 2, should be 1: In scope SELECT tryIdnaEncode(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:10:20.723328 [ 20345 ] {32c12277-bab2-4b6e-a436-d1bb7b0fcbb4} executeQuery: Code: 42. DB::Exception: Number of arguments for function tryPunycodeDecode doesn't match: passed 2, should be 1: In scope SELECT tryPunycodeDecode(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT tryPunycodeDecode(NULL, NULL);) 2025.09.09 15:10:20.735407 [ 20345 ] {32c12277-bab2-4b6e-a436-d1bb7b0fcbb4} TCPHandler: Code: 42. DB::Exception: Number of arguments for function tryPunycodeDecode doesn't match: passed 2, should be 1: In scope SELECT tryPunycodeDecode(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:10:20.778222 [ 2953 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:10:20.840473 [ 2933 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:10:21.267927 [ 2978 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:10:21.481599 [ 2992 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:10:21.677297 [ 20345 ] {4ce5b5dd-cffb-4a5d-a6b9-1e722639202a} executeQuery: Code: 43. DB::Exception: First argument for function tupleElement must be tuple or array of tuple. Actual Nullable(Nothing): In scope SELECT tupleElement(NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT tupleElement(NULL, NULL);) 2025.09.09 15:10:21.680097 [ 20345 ] {4ce5b5dd-cffb-4a5d-a6b9-1e722639202a} TCPHandler: Code: 43. DB::Exception: First argument for function tupleElement must be tuple or array of tuple. Actual Nullable(Nothing): In scope SELECT tupleElement(NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.09.09 15:10:21.810482 [ 2973 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:10:21.926893 [ 3001 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:10:22.269800 [ 3033 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:10:22.361006 [ 3722 ] {a8e0542f-fd2d-4528-baae-c7356f55fc17} executeQuery: Code: 41. DB::Exception: Cannot read DateTime: unexpected word: In scope SELECT toDayOfWeek('invalid'). (CANNOT_PARSE_DATETIME) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:36036) (comment: 01661_week_functions_string_args.sql) (in query: SELECT toDayOfWeek('invalid');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aac868e 4. ./build_docker/./src/IO/parseDateTimeBestEffort.cpp:99: auto void DB::(anonymous namespace)::parseDateTimeBestEffortImpl(long&, DB::ReadBuffer&, DateLUTImpl const&, DateLUTImpl const&, DB::(anonymous namespace)::DateTimeSubsecondPart*, char const*)::'lambda'(int, FormatStringHelperImpl::type...>, $T&&...)::operator()<>(int, FormatStringHelperImpl::type...>, $T&&...) const @ 0x000000001af3d7a3 5. ./build_docker/./src/IO/parseDateTimeBestEffort.cpp:348: DB::parseDateTime64BestEffort(DB::DateTime64&, unsigned int, DB::ReadBuffer&, DateLUTImpl const&, DateLUTImpl const&) @ 0x000000001af2540e 6. COW::immutable_ptr DB::CustomWeekTransformImpl, false>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::ToDayOfWeekImpl) @ 0x00000000185f4b14 7. DB::FunctionCustomWeekToSomething, DB::ToDayOfWeekImpl>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000185efbe6 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aa8c635 9. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aac91d5 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000cccccfb 11. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000cccc1ab 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccccc2a 13. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccce65c 14. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd2030 15. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002839a3af 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000028367bce 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028366290 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283b62c9 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002835ae03 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000028359104 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000028357f0d 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002921bdcc 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&) @ 0x000000002941f313 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&) @ 0x0000000029419aef 25. ./contrib/llvm-project/libcxx/include/vector:432: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000029421f5d 26. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000029344c1b 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*) @ 0x0000000029b3703b 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 29. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 30. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 2025.09.09 15:10:22.366273 [ 3722 ] {a8e0542f-fd2d-4528-baae-c7356f55fc17} TCPHandler: Code: 41. DB::Exception: Cannot read DateTime: unexpected word: In scope SELECT toDayOfWeek('invalid'). (CANNOT_PARSE_DATETIME), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aac868e 4. ./build_docker/./src/IO/parseDateTimeBestEffort.cpp:99: auto void DB::(anonymous namespace)::parseDateTimeBestEffortImpl(long&, DB::ReadBuffer&, DateLUTImpl const&, DateLUTImpl const&, DB::(anonymous namespace)::DateTimeSubsecondPart*, char const*)::'lambda'(int, FormatStringHelperImpl::type...>, $T&&...)::operator()<>(int, FormatStringHelperImpl::type...>, $T&&...) const @ 0x000000001af3d7a3 5. ./build_docker/./src/IO/parseDateTimeBestEffort.cpp:348: DB::parseDateTime64BestEffort(DB::DateTime64&, unsigned int, DB::ReadBuffer&, DateLUTImpl const&, DateLUTImpl const&) @ 0x000000001af2540e 6. COW::immutable_ptr DB::CustomWeekTransformImpl, false>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::ToDayOfWeekImpl) @ 0x00000000185f4b14 7. DB::FunctionCustomWeekToSomething, DB::ToDayOfWeekImpl>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000185efbe6 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aa8c635 9. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aac91d5 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000cccccfb 11. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000cccc1ab 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccccc2a 13. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccce65c 14. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd2030 15. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002839a3af 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000028367bce 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028366290 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283b62c9 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002835ae03 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000028359104 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000028357f0d 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002921bdcc 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&) @ 0x000000002941f313 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&) @ 0x0000000029419aef 25. ./contrib/llvm-project/libcxx/include/vector:432: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000029421f5d 26. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000029344c1b 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*) @ 0x0000000029b3703b 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 29. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 30. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 2025.09.09 15:10:22.484047 [ 3048 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:10:22.549927 [ 5446 ] {} 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. ./contrib/llvm-project/libcxx/include/string:1499: _ZN12Coordination9ExceptionC2IRA41_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x000000002cb2daa6 3. ./src/Common/ZooKeeper/IKeeper.h:509: _ZN12Coordination9Exception11fromMessageIRA41_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEES0_NS_5ErrorEOS5_ @ 0x000000002e6d1195 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1660: Coordination::ZooKeeper::maybeInjectRecvFault() @ 0x000000002e6c134a 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:0: Coordination::ZooKeeper::receiveEvent() @ 0x000000002e6bf27c 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:0: Coordination::ZooKeeper::receiveThread() @ 0x000000002e6be17c 7. ./src/Common/ThreadPool.h:312: 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*) @ 0x000000002e6ceaa7 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 10. asan_thread_start(void*) @ 0x000000000aa43059 11. ? @ 0x00007f35aab92ac3 12. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:10:22.555793 [ 3086 ] {} test_3.part_log_profile_events_r2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.09.09 15:10:22.562446 [ 3079 ] {} test_3.part_header_r2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.09.09 15:10:22.564008 [ 3095 ] {} test_3.part_header_r1 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.09.09 15:10:22.573752 [ 3106 ] {} test_3.part_log_profile_events_r1 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.09.09 15:10:22.575957 [ 3098 ] {} test_3.test_03217_merge_replica_2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.09.09 15:10:22.577362 [ 3103 ] {} test_3.src (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.09.09 15:10:22.578767 [ 3108 ] {} test_3.test_03217_merge_replica_1 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.09.09 15:10:22.580306 [ 3100 ] {} test_15.primary_key (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.09.09 15:10:22.581670 [ 3069 ] {} test_1.order_by_all (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.09.09 15:10:22.582399 [ 3112 ] {} test_3.part_header_r1 (ReplicatedMergeTreeCleanupThread): void DB::ReplicatedMergeTreeCleanupThread::run(): Code: 999. Coordination::Exception: Coordination error: Connection loss, path /clickhouse/tables/00814_replicated_minimalistic_part_header_zookeeper_test_3/test_00814/part_header/s1/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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: Coordination::Exception::Exception(Coordination::Error, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x00000000264863d9 4. ./src/Common/ZooKeeper/IKeeper.h:501: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x00000000264847c3 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:373: zkutil::ZooKeeper::tryGetChildrenWatch(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000002e5ea628 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:346: zkutil::ZooKeeper::tryGetChildren(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr const&, Coordination::ListRequestType) @ 0x000000002e5e9d09 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:514: DB::ReplicatedMergeTreeCleanupThread::getBlocksSortedByTime(String const&, zkutil::ZooKeeper&, std::vector>&, std::map, std::less, std::allocator>>>&) @ 0x000000002ca25d67 8. ./contrib/llvm-project/libcxx/include/vector:553: DB::ReplicatedMergeTreeCleanupThread::clearOldBlocks(String const&, unsigned long, unsigned long, std::map, std::less, std::allocator>>>&) @ 0x000000002ca1d797 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:165: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x000000002ca1548f 10. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:50: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x000000002ca13666 11. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 13. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 16. asan_thread_start(void*) @ 0x000000000aa43059 17. ? @ 0x00007f35aab92ac3 18. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:10:22.582760 [ 3089 ] {} test_3.part_header_r2 (ReplicatedMergeTreeCleanupThread): void DB::ReplicatedMergeTreeCleanupThread::run(): Code: 999. Coordination::Exception: Coordination error: Connection loss, path /clickhouse/tables/00814_replicated_minimalistic_part_header_zookeeper_test_3/test_00814/part_header/s1/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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: Coordination::Exception::Exception(Coordination::Error, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x00000000264863d9 4. ./src/Common/ZooKeeper/IKeeper.h:501: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x00000000264847c3 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:601: zkutil::ZooKeeper::existsWatch(String const&, Coordination::Stat*, std::function) @ 0x000000002e5f1707 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002e5ebc63 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:203: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x000000002ca16d1a 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x000000002ca15340 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:50: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x000000002ca13666 10. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 12. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 15. asan_thread_start(void*) @ 0x000000000aa43059 16. ? @ 0x00007f35aab92ac3 17. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:10:22.633667 [ 3722 ] {ee3d6745-4dd4-4e2f-a7f6-0f2a8faf6f2a} executeQuery: Code: 41. DB::Exception: Cannot read DateTime: unexpected word: In scope SELECT toWeek('invalid'). (CANNOT_PARSE_DATETIME) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:36036) (comment: 01661_week_functions_string_args.sql) (in query: SELECT toWeek('invalid');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aac868e 4. ./build_docker/./src/IO/parseDateTimeBestEffort.cpp:99: auto void DB::(anonymous namespace)::parseDateTimeBestEffortImpl(long&, DB::ReadBuffer&, DateLUTImpl const&, DateLUTImpl const&, DB::(anonymous namespace)::DateTimeSubsecondPart*, char const*)::'lambda'(int, FormatStringHelperImpl::type...>, $T&&...)::operator()<>(int, FormatStringHelperImpl::type...>, $T&&...) const @ 0x000000001af3d7a3 5. ./build_docker/./src/IO/parseDateTimeBestEffort.cpp:348: DB::parseDateTime64BestEffort(DB::DateTime64&, unsigned int, DB::ReadBuffer&, DateLUTImpl const&, DateLUTImpl const&) @ 0x000000001af2540e 6. COW::immutable_ptr DB::CustomWeekTransformImpl, false>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::ToWeekImpl) @ 0x00000000185cc711 7. DB::FunctionCustomWeekToSomething, DB::ToWeekImpl>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000185c7d86 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aa8c635 9. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aac91d5 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000cccccfb 11. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000cccc1ab 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccccc2a 13. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccce65c 14. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd2030 15. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002839a3af 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000028367bce 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028366290 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283b62c9 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002835ae03 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000028359104 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000028357f0d 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002921bdcc 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&) @ 0x000000002941f313 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&) @ 0x0000000029419aef 25. ./contrib/llvm-project/libcxx/include/vector:432: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000029421f5d 26. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000029344c1b 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*) @ 0x0000000029b3703b 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 29. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 30. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 2025.09.09 15:10:22.635856 [ 3722 ] {ee3d6745-4dd4-4e2f-a7f6-0f2a8faf6f2a} TCPHandler: Code: 41. DB::Exception: Cannot read DateTime: unexpected word: In scope SELECT toWeek('invalid'). (CANNOT_PARSE_DATETIME), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aac868e 4. ./build_docker/./src/IO/parseDateTimeBestEffort.cpp:99: auto void DB::(anonymous namespace)::parseDateTimeBestEffortImpl(long&, DB::ReadBuffer&, DateLUTImpl const&, DateLUTImpl const&, DB::(anonymous namespace)::DateTimeSubsecondPart*, char const*)::'lambda'(int, FormatStringHelperImpl::type...>, $T&&...)::operator()<>(int, FormatStringHelperImpl::type...>, $T&&...) const @ 0x000000001af3d7a3 5. ./build_docker/./src/IO/parseDateTimeBestEffort.cpp:348: DB::parseDateTime64BestEffort(DB::DateTime64&, unsigned int, DB::ReadBuffer&, DateLUTImpl const&, DateLUTImpl const&) @ 0x000000001af2540e 6. COW::immutable_ptr DB::CustomWeekTransformImpl, false>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::ToWeekImpl) @ 0x00000000185cc711 7. DB::FunctionCustomWeekToSomething, DB::ToWeekImpl>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000185c7d86 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aa8c635 9. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aac91d5 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000cccccfb 11. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000cccc1ab 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccccc2a 13. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccce65c 14. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd2030 15. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002839a3af 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000028367bce 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028366290 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283b62c9 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002835ae03 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000028359104 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000028357f0d 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002921bdcc 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&) @ 0x000000002941f313 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&) @ 0x0000000029419aef 25. ./contrib/llvm-project/libcxx/include/vector:432: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000029421f5d 26. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000029344c1b 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*) @ 0x0000000029b3703b 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 29. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 30. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 2025.09.09 15:10:22.812763 [ 3093 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:10:22.855619 [ 3722 ] {04609021-b780-4571-9765-77a33c65955d} executeQuery: Code: 41. DB::Exception: Cannot read DateTime: unexpected word: In scope SELECT toYearWeek('invalid'). (CANNOT_PARSE_DATETIME) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:36036) (comment: 01661_week_functions_string_args.sql) (in query: SELECT toYearWeek('invalid');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aac868e 4. ./build_docker/./src/IO/parseDateTimeBestEffort.cpp:99: auto void DB::(anonymous namespace)::parseDateTimeBestEffortImpl(long&, DB::ReadBuffer&, DateLUTImpl const&, DateLUTImpl const&, DB::(anonymous namespace)::DateTimeSubsecondPart*, char const*)::'lambda'(int, FormatStringHelperImpl::type...>, $T&&...)::operator()<>(int, FormatStringHelperImpl::type...>, $T&&...) const @ 0x000000001af3d7a3 5. ./build_docker/./src/IO/parseDateTimeBestEffort.cpp:348: DB::parseDateTime64BestEffort(DB::DateTime64&, unsigned int, DB::ReadBuffer&, DateLUTImpl const&, DateLUTImpl const&) @ 0x000000001af2540e 6. COW::immutable_ptr DB::CustomWeekTransformImpl, false>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::ToYearWeekImpl) @ 0x00000000185d3871 7. DB::FunctionCustomWeekToSomething, DB::ToYearWeekImpl>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000185cf8e6 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aa8c635 9. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aac91d5 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000cccccfb 11. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000cccc1ab 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccccc2a 13. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccce65c 14. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd2030 15. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002839a3af 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000028367bce 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028366290 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283b62c9 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002835ae03 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000028359104 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000028357f0d 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002921bdcc 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&) @ 0x000000002941f313 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&) @ 0x0000000029419aef 25. ./contrib/llvm-project/libcxx/include/vector:432: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000029421f5d 26. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000029344c1b 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*) @ 0x0000000029b3703b 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 29. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 30. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 2025.09.09 15:10:22.857435 [ 3722 ] {04609021-b780-4571-9765-77a33c65955d} TCPHandler: Code: 41. DB::Exception: Cannot read DateTime: unexpected word: In scope SELECT toYearWeek('invalid'). (CANNOT_PARSE_DATETIME), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aac868e 4. ./build_docker/./src/IO/parseDateTimeBestEffort.cpp:99: auto void DB::(anonymous namespace)::parseDateTimeBestEffortImpl(long&, DB::ReadBuffer&, DateLUTImpl const&, DateLUTImpl const&, DB::(anonymous namespace)::DateTimeSubsecondPart*, char const*)::'lambda'(int, FormatStringHelperImpl::type...>, $T&&...)::operator()<>(int, FormatStringHelperImpl::type...>, $T&&...) const @ 0x000000001af3d7a3 5. ./build_docker/./src/IO/parseDateTimeBestEffort.cpp:348: DB::parseDateTime64BestEffort(DB::DateTime64&, unsigned int, DB::ReadBuffer&, DateLUTImpl const&, DateLUTImpl const&) @ 0x000000001af2540e 6. COW::immutable_ptr DB::CustomWeekTransformImpl, false>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::ToYearWeekImpl) @ 0x00000000185d3871 7. DB::FunctionCustomWeekToSomething, DB::ToYearWeekImpl>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000185cf8e6 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aa8c635 9. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aac91d5 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000cccccfb 11. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000cccc1ab 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccccc2a 13. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccce65c 14. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd2030 15. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002839a3af 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000028367bce 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028366290 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283b62c9 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002835ae03 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000028359104 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000028357f0d 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002921bdcc 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&) @ 0x000000002941f313 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&) @ 0x0000000029419aef 25. ./contrib/llvm-project/libcxx/include/vector:432: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000029421f5d 26. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000029344c1b 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*) @ 0x0000000029b3703b 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 29. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 30. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 2025.09.09 15:10:22.879747 [ 20345 ] {0f2d2b79-9ff9-4728-ac6c-f11ef23c82ae} executeQuery: Code: 42. DB::Exception: Number of arguments for function tupleNames doesn't match: passed 2, should be 1: In scope SELECT tupleNames(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT tupleNames(NULL, NULL);) 2025.09.09 15:10:22.882494 [ 20345 ] {0f2d2b79-9ff9-4728-ac6c-f11ef23c82ae} TCPHandler: Code: 42. DB::Exception: Number of arguments for function tupleNames doesn't match: passed 2, should be 1: In scope SELECT tupleNames(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:10:22.914065 [ 20345 ] {5c419b47-b135-4e1b-a030-0c6110e0a51a} executeQuery: Code: 42. DB::Exception: Number of arguments for function tupleNegate doesn't match: passed 2, should be 1: In scope SELECT tupleNegate(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT tupleNegate(NULL, NULL);) 2025.09.09 15:10:22.917356 [ 20345 ] {5c419b47-b135-4e1b-a030-0c6110e0a51a} TCPHandler: Code: 42. DB::Exception: Number of arguments for function tupleNegate doesn't match: passed 2, should be 1: In scope SELECT tupleNegate(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:10:22.929221 [ 3087 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:10:23.168603 [ 20345 ] {ac6fc04e-d57e-4482-ad39-f29d2ab888be} executeQuery: Code: 42. DB::Exception: Number of arguments for function tupleToNameValuePairs doesn't match: passed 2, should be 1: In scope SELECT tupleToNameValuePairs(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT tupleToNameValuePairs(NULL, NULL);) 2025.09.09 15:10:23.172537 [ 20345 ] {ac6fc04e-d57e-4482-ad39-f29d2ab888be} TCPHandler: Code: 42. DB::Exception: Number of arguments for function tupleToNameValuePairs doesn't match: passed 2, should be 1: In scope SELECT tupleToNameValuePairs(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:10:23.265232 [ 20345 ] {3f0fce66-2eb4-42b1-84fc-9b8fdf526800} executeQuery: Code: 42. DB::Exception: Number of arguments for function upper doesn't match: passed 2, should be 1: In scope SELECT ucase(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT ucase(NULL, NULL);) 2025.09.09 15:10:23.272171 [ 20345 ] {3f0fce66-2eb4-42b1-84fc-9b8fdf526800} TCPHandler: Code: 42. DB::Exception: Number of arguments for function upper doesn't match: passed 2, should be 1: In scope SELECT ucase(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:10:23.272342 [ 3174 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:10:23.334675 [ 20345 ] {cf152de1-6256-4b72-8bd6-d69a4e824d3a} executeQuery: Code: 42. DB::Exception: Number of arguments for function unbin doesn't match: passed 2, should be 1: In scope SELECT unbin(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT unbin(NULL, NULL);) 2025.09.09 15:10:23.344607 [ 20345 ] {cf152de1-6256-4b72-8bd6-d69a4e824d3a} TCPHandler: Code: 42. DB::Exception: Number of arguments for function unbin doesn't match: passed 2, should be 1: In scope SELECT unbin(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:10:23.424303 [ 20345 ] {fe0da332-73d6-44c2-8a82-041e789ad895} executeQuery: Code: 42. DB::Exception: Number of arguments for function unhex doesn't match: passed 2, should be 1: In scope SELECT unhex(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT unhex(NULL, NULL);) 2025.09.09 15:10:23.432007 [ 20345 ] {fe0da332-73d6-44c2-8a82-041e789ad895} TCPHandler: Code: 42. DB::Exception: Number of arguments for function unhex doesn't match: passed 2, should be 1: In scope SELECT unhex(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:10:23.486361 [ 3139 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:10:23.815158 [ 3198 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:10:23.931662 [ 2752 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:10:24.274540 [ 2758 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:10:24.488209 [ 2762 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:10:24.492376 [ 3722 ] {d163185e-1c96-4157-809a-0f74c6350df8} 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.10505.altinitytest (altinity build)) (from [::1]:36036) (comment: 01661_week_functions_string_args.sql) (in query: SELECT toDayOfWeek(d), toDayOfWeek(dt), toDayOfWeek(dt64), toDayOfWeek(str_d), toDayOfWeek(str_dt), toDayOfWeek(str_dt64) FROM tab ORDER BY d;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af819ed 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af82f33 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002c64fc80 7. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1723: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr, unsigned long, std::shared_ptr, std::equal_to, std::allocator>>>, DB::MergeTreeData const&, std::vector> const&, std::shared_ptr, std::optional&, bool) @ 0x000000002de379fd 8. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1437: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000002de3554f 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:0: DB::ReadFromMergeTree::getAnalysisResult() const @ 0x000000002de41345 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:2022: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000002de4404c 11. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000002ddb933c 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000002ddff11e 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000002942117f 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x00000000294209e7 15. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b382fc 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 18. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 22. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:10:24.494933 [ 3722 ] {d163185e-1c96-4157-809a-0f74c6350df8} 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af819ed 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af82f33 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002c64fc80 7. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1723: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr, unsigned long, std::shared_ptr, std::equal_to, std::allocator>>>, DB::MergeTreeData const&, std::vector> const&, std::shared_ptr, std::optional&, bool) @ 0x000000002de379fd 8. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1437: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000002de3554f 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:0: DB::ReadFromMergeTree::getAnalysisResult() const @ 0x000000002de41345 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:2022: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000002de4404c 11. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000002ddb933c 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000002ddff11e 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000002942117f 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x00000000294209e7 15. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b382fc 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 18. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 22. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 23. asan_thread_start(void*) @ 0x000000000aa43059 24. ? @ 0x00007f35aab92ac3 25. ? @ 0x00007f35aac24850 2025.09.09 15:10:24.596307 [ 20345 ] {06ffcbc8-d57c-4181-b01b-381f293e60b7} executeQuery: Code: 42. DB::Exception: Number of arguments for function upper doesn't match: passed 2, should be 1: In scope SELECT upper(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT upper(NULL, NULL);) 2025.09.09 15:10:24.607526 [ 20345 ] {06ffcbc8-d57c-4181-b01b-381f293e60b7} TCPHandler: Code: 42. DB::Exception: Number of arguments for function upper doesn't match: passed 2, should be 1: In scope SELECT upper(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:10:24.663186 [ 20345 ] {aed51f0f-c686-427e-888a-96d9474ab038} executeQuery: Code: 42. DB::Exception: Number of arguments for function upperUTF8 doesn't match: passed 2, should be 1: In scope SELECT upperUTF8(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT upperUTF8(NULL, NULL);) 2025.09.09 15:10:24.670899 [ 20345 ] {aed51f0f-c686-427e-888a-96d9474ab038} TCPHandler: Code: 42. DB::Exception: Number of arguments for function upperUTF8 doesn't match: passed 2, should be 1: In scope SELECT upperUTF8(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:10:24.741073 [ 20345 ] {b738e191-8091-4a7d-9e3c-74b3b72f6a7a} executeQuery: Code: 42. DB::Exception: Number of arguments for function uptime doesn't match: passed 2, should be 0: In scope SELECT uptime(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT uptime(NULL, NULL);) 2025.09.09 15:10:24.746834 [ 20345 ] {b738e191-8091-4a7d-9e3c-74b3b72f6a7a} TCPHandler: Code: 42. DB::Exception: Number of arguments for function uptime doesn't match: passed 2, should be 0: In scope SELECT uptime(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:10:24.774803 [ 20881 ] {4208bb2e-c3d9-4841-818d-39947e54b670} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:58368) (comment: 01661_week_functions_string_args.sql) (in query: DROP DATABASE IF EXISTS test_5anru7hj ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aac868e 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x00000000286b57c7 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x00000000291f5630 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:361: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000291edc97 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x00000000291ebf11 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x00000000291eb7ed 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b382fc 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1529: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000029b3ed3f 11. ./build_docker/./src/Server/HTTPHandler.cpp:529: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000002d0662d1 12. ./build_docker/./src/Server/HTTPHandler.cpp:705: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000002d06d139 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000002d1cc337 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 18. asan_thread_start(void*) @ 0x000000000aa43059 19. ? @ 0x00007f35aab92ac3 20. ? @ 0x00007f35aac24850 2025.09.09 15:10:24.779849 [ 20881 ] {4208bb2e-c3d9-4841-818d-39947e54b670} DynamicQueryHandler: Code: 219. DB::Exception: New table 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aac868e 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x00000000286b57c7 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x00000000291f5630 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:361: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000291edc97 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x00000000291ebf11 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x00000000291eb7ed 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b382fc 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1529: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000029b3ed3f 11. ./build_docker/./src/Server/HTTPHandler.cpp:529: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000002d0662d1 12. ./build_docker/./src/Server/HTTPHandler.cpp:705: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000002d06d139 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000002d1cc337 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 18. asan_thread_start(void*) @ 0x000000000aa43059 19. ? @ 0x00007f35aab92ac3 20. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:10:24.817058 [ 2797 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:10:24.852931 [ 3722 ] {d207cac2-d7b3-466b-ae88-3eccc8730feb} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:58384) (comment: 01661_week_functions_string_args.sql) (in query: DROP DATABASE IF EXISTS test_5anru7hj ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aac868e 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x00000000286b57c7 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x00000000291f5630 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:361: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000291edc97 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x00000000291ebf11 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x00000000291eb7ed 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b382fc 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1529: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000029b3ed3f 11. ./build_docker/./src/Server/HTTPHandler.cpp:529: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000002d0662d1 12. ./build_docker/./src/Server/HTTPHandler.cpp:705: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000002d06d139 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000002d1cc337 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 18. asan_thread_start(void*) @ 0x000000000aa43059 19. ? @ 0x00007f35aab92ac3 20. ? @ 0x00007f35aac24850 2025.09.09 15:10:24.864036 [ 20345 ] {1dd30b48-7887-49b2-a6fc-1cebf7b7455e} executeQuery: Code: 42. DB::Exception: Number of arguments for function currentUser doesn't match: passed 2, should be 0: In scope SELECT user(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT user(NULL, NULL);) 2025.09.09 15:10:24.864302 [ 3722 ] {d207cac2-d7b3-466b-ae88-3eccc8730feb} DynamicQueryHandler: Code: 219. DB::Exception: New table 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aac868e 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x00000000286b57c7 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x00000000291f5630 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:361: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000291edc97 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x00000000291ebf11 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x00000000291eb7ed 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b382fc 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1529: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000029b3ed3f 11. ./build_docker/./src/Server/HTTPHandler.cpp:529: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000002d0662d1 12. ./build_docker/./src/Server/HTTPHandler.cpp:705: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000002d06d139 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000002d1cc337 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 18. asan_thread_start(void*) @ 0x000000000aa43059 19. ? @ 0x00007f35aab92ac3 20. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:10:24.867835 [ 20345 ] {1dd30b48-7887-49b2-a6fc-1cebf7b7455e} TCPHandler: Code: 42. DB::Exception: Number of arguments for function currentUser doesn't match: passed 2, should be 0: In scope SELECT user(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:10:24.933842 [ 2788 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:10:24.943223 [ 20421 ] {} test_5anru7hj.tab (7cf84087-dfe7-4abf-8368-b3291bcb0d27): dropAllData: got exception removing parts from disk, removing successfully removed parts from memory. 2025.09.09 15:10:24.944257 [ 20421 ] {} DatabaseCatalog: Cannot drop table test_5anru7hj.tab (7cf84087-dfe7-4abf-8368-b3291bcb0d27). 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af819ed 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80746 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000263a174e 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002c47c445 8. ./contrib/llvm-project/libcxx/include/vector:547: DB::MergeTreeData::clearPartsFromFilesystem(std::vector, std::allocator>> const&, bool, std::unordered_set, std::equal_to, std::allocator>*) @ 0x000000002c47a78e 9. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::dropAllData() @ 0x000000002c4862d9 10. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::dropTableFinally(DB::DatabaseCatalog::TableMarkedAsDropped const&) @ 0x00000000286c7c77 11. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: void std::__function::__policy_invoker::__call_impl, std::allocator>>)::$_0, void ()>>(std::__function::__policy_storage const*) @ 0x00000000286d9744 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000263a3ea5 13. ./contrib/llvm-project/libcxx/include/future:0: std::packaged_task::operator()() @ 0x000000001bba33ac 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7eaf0 15. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001af8a79f 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 18. asan_thread_start(void*) @ 0x000000000aa43059 19. ? @ 0x00007f35aab92ac3 20. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:10:25.276965 [ 2840 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:10:25.490225 [ 2876 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:10:25.788543 [ 20345 ] {d70d611e-55b8-45bb-96fe-583d9a06aef5} executeQuery: Code: 43. DB::Exception: First argument for function variantElement must be Variant or Array of Variant. Actual Nullable(Nothing): In scope SELECT variantElement(NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT variantElement(NULL, NULL);) 2025.09.09 15:10:25.791991 [ 20345 ] {d70d611e-55b8-45bb-96fe-583d9a06aef5} TCPHandler: Code: 43. DB::Exception: First argument for function variantElement must be Variant or Array of Variant. Actual Nullable(Nothing): In scope SELECT variantElement(NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.09.09 15:10:25.819494 [ 2910 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:10:25.840277 [ 20345 ] {c67298c1-4763-45bc-b7b4-50f49a640a3c} executeQuery: Code: 42. DB::Exception: Number of arguments for function variantType doesn't match: passed 2, should be 1: In scope SELECT variantType(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT variantType(NULL, NULL);) 2025.09.09 15:10:25.844658 [ 20345 ] {c67298c1-4763-45bc-b7b4-50f49a640a3c} TCPHandler: Code: 42. DB::Exception: Number of arguments for function variantType doesn't match: passed 2, should be 1: In scope SELECT variantType(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:10:25.936451 [ 2815 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:10:26.165460 [ 20345 ] {b6426f79-cfed-4546-a49f-93836095b85d} executeQuery: Code: 42. DB::Exception: Number of arguments for function version doesn't match: passed 2, should be 0: In scope SELECT version(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT version(NULL, NULL);) 2025.09.09 15:10:26.171274 [ 20345 ] {b6426f79-cfed-4546-a49f-93836095b85d} TCPHandler: Code: 42. DB::Exception: Number of arguments for function version doesn't match: passed 2, should be 0: In scope SELECT version(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:10:26.217195 [ 20345 ] {342067f3-db69-41d2-8e6a-525b2b169eaa} executeQuery: Code: 42. DB::Exception: Number of arguments for function visibleWidth doesn't match: passed 2, should be 1: In scope SELECT visibleWidth(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT visibleWidth(NULL, NULL);) 2025.09.09 15:10:26.219675 [ 20345 ] {342067f3-db69-41d2-8e6a-525b2b169eaa} TCPHandler: Code: 42. DB::Exception: Number of arguments for function visibleWidth doesn't match: passed 2, should be 1: In scope SELECT visibleWidth(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:10:26.279556 [ 2861 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:10:26.492883 [ 2890 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:10:26.822862 [ 2916 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:10:26.939766 [ 2961 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:10:27.183473 [ 20345 ] {2776416b-7a88-410c-8864-6f621a812142} executeQuery: Code: 42. DB::Exception: Number of arguments for function widthBucket doesn't match: passed 2, should be 4: In scope SELECT widthBucket(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT widthBucket(NULL, NULL);) 2025.09.09 15:10:27.188841 [ 20345 ] {2776416b-7a88-410c-8864-6f621a812142} TCPHandler: Code: 42. DB::Exception: Number of arguments for function widthBucket doesn't match: passed 2, should be 4: In scope SELECT widthBucket(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:10:27.241532 [ 20345 ] {c8d906dc-a7b6-46a4-94dd-2fdb50374709} executeQuery: Code: 42. DB::Exception: Number of arguments for function widthBucket doesn't match: passed 2, should be 4: In scope SELECT width_bucket(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT width_bucket(NULL, NULL);) 2025.09.09 15:10:27.245215 [ 20345 ] {c8d906dc-a7b6-46a4-94dd-2fdb50374709} TCPHandler: Code: 42. DB::Exception: Number of arguments for function widthBucket doesn't match: passed 2, should be 4: In scope SELECT width_bucket(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:10:27.281604 [ 2944 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:10:27.501143 [ 2993 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:10:27.523935 [ 20345 ] {15b49f2c-5bc7-46f9-a5a8-9cf3c41130c3} executeQuery: Code: 42. DB::Exception: Number of arguments for function wkt doesn't match: passed 2, should be 1: In scope SELECT wkt(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT wkt(NULL, NULL);) 2025.09.09 15:10:27.530344 [ 20345 ] {15b49f2c-5bc7-46f9-a5a8-9cf3c41130c3} TCPHandler: Code: 42. DB::Exception: Number of arguments for function wkt doesn't match: passed 2, should be 1: In scope SELECT wkt(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:10:27.835425 [ 3028 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:10:27.943246 [ 3044 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:10:28.286733 [ 3094 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:10:28.542281 [ 3114 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:10:28.838506 [ 3098 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:10:28.957916 [ 3155 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:10:29.291157 [ 3091 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:10:29.544173 [ 3211 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:10:29.739048 [ 20345 ] {c9076d54-01f4-411a-8b23-c99d006ff4f9} executeQuery: Code: 42. DB::Exception: Number of arguments for function yesterday doesn't match: passed 2, should be 0: In scope SELECT yesterday(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT yesterday(NULL, NULL);) 2025.09.09 15:10:29.758076 [ 20345 ] {c9076d54-01f4-411a-8b23-c99d006ff4f9} TCPHandler: Code: 42. DB::Exception: Number of arguments for function yesterday doesn't match: passed 2, should be 0: In scope SELECT yesterday(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:10:29.841128 [ 20345 ] {0e2bae0d-a4bd-4d72-8df9-492988da8ff1} executeQuery: Code: 42. DB::Exception: Number of arguments for function zookeeperSessionUptime doesn't match: passed 2, should be 0: In scope SELECT zookeeperSessionUptime(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45878) (comment: 00534_functions_bad_arguments8.sh) (in query: SELECT zookeeperSessionUptime(NULL, NULL);) 2025.09.09 15:10:29.841918 [ 3217 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:10:29.846915 [ 20345 ] {0e2bae0d-a4bd-4d72-8df9-492988da8ff1} TCPHandler: Code: 42. DB::Exception: Number of arguments for function zookeeperSessionUptime doesn't match: passed 2, should be 0: In scope SELECT zookeeperSessionUptime(NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.09.09 15:10:29.960494 [ 3168 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:10:30.293918 [ 3235 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:10:30.546885 [ 2774 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:10:30.883312 [ 2775 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:10:30.969186 [ 2771 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:10:31.381177 [ 2839 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:10:31.587735 [ 2854 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:10:31.774274 [ 20881 ] {bde18a8b-59f4-4fb8-8969-050e7e6e49f7} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=1, jobs=1). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:55202) (comment: 02513_analyzer_duplicate_alias_crash_fix.sql) (in query: SELECT toUInt64(NULL) AS x FROM (SELECT 1) HAVING x IN (SELECT NULL FROM (SELECT x IN (SELECT x IN (SELECT 1), x IN (SELECT 1) FROM (SELECT 1 WHERE x IN (SELECT NULL FROM (SELECT NULL))))));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af80b71 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80746 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d34b5ca 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000002d3486e4 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000002d34827b 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002d36bcf7 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 12. asan_thread_start(void*) @ 0x000000000aa43059 13. ? @ 0x00007f35aab92ac3 14. ? @ 0x00007f35aac24850 2025.09.09 15:10:31.781560 [ 20881 ] {bde18a8b-59f4-4fb8-8969-050e7e6e49f7} 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af80b71 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80746 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d34b5ca 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000002d3486e4 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000002d34827b 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002d36bcf7 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 12. asan_thread_start(void*) @ 0x000000000aa43059 13. ? @ 0x00007f35aab92ac3 14. ? @ 0x00007f35aac24850 2025.09.09 15:10:31.909592 [ 2874 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:10:31.971101 [ 2891 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:10:32.383232 [ 2904 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:10:32.589580 [ 2858 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:10:32.912118 [ 2918 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:10:32.972835 [ 2948 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:10:33.385598 [ 2983 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:10:33.591622 [ 3026 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:10:33.914543 [ 3027 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:10:33.975703 [ 3048 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:10:34.382888 [ 3722 ] {1b4d18b7-7ff8-4e69-8182-03cec2415ca4} executeQuery: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:55230) (comment: 00849_multiple_comma_join_2.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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x0000000026f807e3 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x000000002853b6ad 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterSetQuery::execute() @ 0x00000000294f603b 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b382fc 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 15:10:34.387355 [ 3114 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:10:34.398449 [ 3722 ] {1b4d18b7-7ff8-4e69-8182-03cec2415ca4} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c286b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8148e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f802d1 6. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x0000000026f807e3 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x000000002853b6ad 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterSetQuery::execute() @ 0x00000000294f603b 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b382fc 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 15:10:34.593613 [ 3144 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:10:34.714224 [ 20881 ] {81f030e5-8bf9-4c0d-bb6e-d896deb0de4f} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45796) (comment: 00849_multiple_comma_join_2.sql) (in query: DROP DATABASE IF EXISTS test_g8h39kec ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aac868e 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x00000000286b57c7 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x00000000291f5630 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:361: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000291edc97 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x00000000291ebf11 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x00000000291eb7ed 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b382fc 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1529: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000029b3ed3f 11. ./build_docker/./src/Server/HTTPHandler.cpp:529: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000002d0662d1 12. ./build_docker/./src/Server/HTTPHandler.cpp:705: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000002d06d139 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000002d1cc337 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 18. asan_thread_start(void*) @ 0x000000000aa43059 19. ? @ 0x00007f35aab92ac3 20. ? @ 0x00007f35aac24850 2025.09.09 15:10:34.717712 [ 20881 ] {81f030e5-8bf9-4c0d-bb6e-d896deb0de4f} DynamicQueryHandler: Code: 219. DB::Exception: New table 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aac868e 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x00000000286b57c7 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x00000000291f5630 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:361: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000291edc97 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x00000000291ebf11 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x00000000291eb7ed 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b382fc 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1529: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000029b3ed3f 11. ./build_docker/./src/Server/HTTPHandler.cpp:529: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000002d0662d1 12. ./build_docker/./src/Server/HTTPHandler.cpp:705: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000002d06d139 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000002d1cc337 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 18. asan_thread_start(void*) @ 0x000000000aa43059 19. ? @ 0x00007f35aab92ac3 20. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:10:34.814478 [ 20380 ] {a53ba5e4-3503-49b0-9e73-4390844d4b2b} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45804) (comment: 00849_multiple_comma_join_2.sql) (in query: DROP DATABASE IF EXISTS test_g8h39kec ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aac868e 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x00000000286b57c7 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x00000000291f5630 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:361: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000291edc97 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x00000000291ebf11 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x00000000291eb7ed 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b382fc 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1529: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000029b3ed3f 11. ./build_docker/./src/Server/HTTPHandler.cpp:529: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000002d0662d1 12. ./build_docker/./src/Server/HTTPHandler.cpp:705: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000002d06d139 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000002d1cc337 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 18. asan_thread_start(void*) @ 0x000000000aa43059 19. ? @ 0x00007f35aab92ac3 20. ? @ 0x00007f35aac24850 2025.09.09 15:10:34.819066 [ 20380 ] {a53ba5e4-3503-49b0-9e73-4390844d4b2b} DynamicQueryHandler: Code: 219. DB::Exception: New table 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aac868e 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x00000000286b57c7 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x00000000291f5630 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:361: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000291edc97 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x00000000291ebf11 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x00000000291eb7ed 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b382fc 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1529: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000029b3ed3f 11. ./build_docker/./src/Server/HTTPHandler.cpp:529: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000002d0662d1 12. ./build_docker/./src/Server/HTTPHandler.cpp:705: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000002d06d139 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000002d1cc337 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 18. asan_thread_start(void*) @ 0x000000000aa43059 19. ? @ 0x00007f35aab92ac3 20. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:10:34.919793 [ 3174 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:10:34.976949 [ 20379 ] {140f6026-dace-47d3-84ed-731d1735b418} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45812) (comment: 00849_multiple_comma_join_2.sql) (in query: DROP DATABASE IF EXISTS test_g8h39kec ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aac868e 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x00000000286b57c7 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x00000000291f5630 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:361: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000291edc97 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x00000000291ebf11 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x00000000291eb7ed 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b382fc 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1529: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000029b3ed3f 11. ./build_docker/./src/Server/HTTPHandler.cpp:529: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000002d0662d1 12. ./build_docker/./src/Server/HTTPHandler.cpp:705: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000002d06d139 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000002d1cc337 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 18. asan_thread_start(void*) @ 0x000000000aa43059 19. ? @ 0x00007f35aab92ac3 20. ? @ 0x00007f35aac24850 2025.09.09 15:10:34.978557 [ 3104 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:10:34.981132 [ 20379 ] {140f6026-dace-47d3-84ed-731d1735b418} DynamicQueryHandler: Code: 219. DB::Exception: New table 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aac868e 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x00000000286b57c7 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x00000000291f5630 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:361: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000291edc97 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x00000000291ebf11 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x00000000291eb7ed 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b382fc 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1529: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000029b3ed3f 11. ./build_docker/./src/Server/HTTPHandler.cpp:529: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000002d0662d1 12. ./build_docker/./src/Server/HTTPHandler.cpp:705: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000002d06d139 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000002d1cc337 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 18. asan_thread_start(void*) @ 0x000000000aa43059 19. ? @ 0x00007f35aab92ac3 20. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:10:35.219014 [ 20353 ] {572849d6-ec2c-47a0-b45e-2fa51e86152d} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45828) (comment: 00849_multiple_comma_join_2.sql) (in query: DROP DATABASE IF EXISTS test_g8h39kec ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aac868e 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x00000000286b57c7 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x00000000291f5630 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:361: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000291edc97 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x00000000291ebf11 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x00000000291eb7ed 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b382fc 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1529: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000029b3ed3f 11. ./build_docker/./src/Server/HTTPHandler.cpp:529: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000002d0662d1 12. ./build_docker/./src/Server/HTTPHandler.cpp:705: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000002d06d139 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000002d1cc337 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 18. asan_thread_start(void*) @ 0x000000000aa43059 19. ? @ 0x00007f35aab92ac3 20. ? @ 0x00007f35aac24850 2025.09.09 15:10:35.229461 [ 20353 ] {572849d6-ec2c-47a0-b45e-2fa51e86152d} DynamicQueryHandler: Code: 219. DB::Exception: New table 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aac868e 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x00000000286b57c7 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x00000000291f5630 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:361: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000291edc97 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x00000000291ebf11 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x00000000291eb7ed 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b382fc 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1529: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000029b3ed3f 11. ./build_docker/./src/Server/HTTPHandler.cpp:529: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000002d0662d1 12. ./build_docker/./src/Server/HTTPHandler.cpp:705: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000002d06d139 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000002d1cc337 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 18. asan_thread_start(void*) @ 0x000000000aa43059 19. ? @ 0x00007f35aab92ac3 20. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:10:35.390060 [ 3156 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:10:35.410232 [ 20351 ] {9ad28fe4-dc96-45bf-82ea-94213002412f} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:45832) (comment: 00849_multiple_comma_join_2.sql) (in query: DROP DATABASE IF EXISTS test_g8h39kec ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aac868e 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x00000000286b57c7 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x00000000291f5630 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:361: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000291edc97 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x00000000291ebf11 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x00000000291eb7ed 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b382fc 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1529: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000029b3ed3f 11. ./build_docker/./src/Server/HTTPHandler.cpp:529: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000002d0662d1 12. ./build_docker/./src/Server/HTTPHandler.cpp:705: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000002d06d139 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000002d1cc337 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 18. asan_thread_start(void*) @ 0x000000000aa43059 19. ? @ 0x00007f35aab92ac3 20. ? @ 0x00007f35aac24850 2025.09.09 15:10:35.415922 [ 20351 ] {9ad28fe4-dc96-45bf-82ea-94213002412f} DynamicQueryHandler: Code: 219. DB::Exception: New table 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aac868e 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x00000000286b57c7 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x00000000291f5630 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:361: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000291edc97 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x00000000291ebf11 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x00000000291eb7ed 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b382fc 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1529: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000029b3ed3f 11. ./build_docker/./src/Server/HTTPHandler.cpp:529: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000002d0662d1 12. ./build_docker/./src/Server/HTTPHandler.cpp:705: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000002d06d139 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000002d1cc337 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 18. asan_thread_start(void*) @ 0x000000000aa43059 19. ? @ 0x00007f35aab92ac3 20. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:10:35.595531 [ 3198 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:10:35.921550 [ 3207 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:10:35.980799 [ 3130 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:10:36.393081 [ 2759 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:10:36.597962 [ 2766 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:10:36.924116 [ 2832 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:10:36.985100 [ 2801 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:10:37.396452 [ 2865 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:10:37.610029 [ 2896 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:10:37.970364 [ 2851 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:10:37.987823 [ 2866 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:10:38.399951 [ 2890 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:10:38.618317 [ 2884 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:10:38.973124 [ 2918 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:10:38.991564 [ 2961 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:10:39.403042 [ 2947 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:10:39.620918 [ 2998 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:10:39.975838 [ 2996 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:10:39.994557 [ 3056 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:10:40.406121 [ 3051 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:10:40.623298 [ 3070 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:10:40.978477 [ 3092 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:10:40.997372 [ 3111 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:10:41.408466 [ 3162 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:10:41.625745 [ 3079 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:10:41.980699 [ 3195 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:10:42.000312 [ 3153 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:10:42.410516 [ 3170 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:10:42.628001 [ 3209 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:10:42.982857 [ 2758 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:10:43.004269 [ 2785 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:10:43.412987 [ 2792 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:10:43.630496 [ 2872 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:10:43.985714 [ 2877 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:10:44.007029 [ 2852 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:10:44.415207 [ 2935 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:10:44.638000 [ 2932 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:10:44.989013 [ 2930 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:10:45.010255 [ 2837 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:10:45.417699 [ 2984 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:10:45.442118 [ 20351 ] {03e3736d-7a64-4fb8-8f57-da77a55fb0a4} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:34312) (comment: 01107_join_right_table_totals.sql) (in query: DROP DATABASE IF EXISTS test_gz9e4z1s ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aac868e 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x00000000286b57c7 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x00000000291f5630 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:361: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000291edc97 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x00000000291ebf11 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x00000000291eb7ed 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b382fc 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1529: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000029b3ed3f 11. ./build_docker/./src/Server/HTTPHandler.cpp:529: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000002d0662d1 12. ./build_docker/./src/Server/HTTPHandler.cpp:705: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000002d06d139 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000002d1cc337 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 18. asan_thread_start(void*) @ 0x000000000aa43059 19. ? @ 0x00007f35aab92ac3 20. ? @ 0x00007f35aac24850 2025.09.09 15:10:45.463350 [ 20351 ] {03e3736d-7a64-4fb8-8f57-da77a55fb0a4} DynamicQueryHandler: Code: 219. DB::Exception: New table 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aac868e 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x00000000286b57c7 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x00000000291f5630 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:361: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000291edc97 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x00000000291ebf11 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x00000000291eb7ed 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b382fc 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1529: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000029b3ed3f 11. ./build_docker/./src/Server/HTTPHandler.cpp:529: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000002d0662d1 12. ./build_docker/./src/Server/HTTPHandler.cpp:705: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000002d06d139 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000002d1cc337 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 18. asan_thread_start(void*) @ 0x000000000aa43059 19. ? @ 0x00007f35aab92ac3 20. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:10:45.637814 [ 20353 ] {c7a58742-4550-4f10-b7bd-207face3a971} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=0, jobs=0). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:34316) (comment: 01107_join_right_table_totals.sql) (in query: DROP DATABASE IF EXISTS test_gz9e4z1s ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af80b71 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80746 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000263a174e 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000291f4e6a 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:361: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000291edc97 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x00000000291ebf11 10. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x00000000291eb7ed 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b382fc 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1529: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000029b3ed3f 13. ./build_docker/./src/Server/HTTPHandler.cpp:529: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000002d0662d1 14. ./build_docker/./src/Server/HTTPHandler.cpp:705: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000002d06d139 15. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000002d1cc337 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 19. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 20. asan_thread_start(void*) @ 0x000000000aa43059 21. ? @ 0x00007f35aab92ac3 22. ? @ 0x00007f35aac24850 2025.09.09 15:10:45.644570 [ 2945 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:10:45.653999 [ 20353 ] {c7a58742-4550-4f10-b7bd-207face3a971} 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af80b71 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80746 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000263a174e 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000291f4e6a 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:361: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000291edc97 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x00000000291ebf11 10. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x00000000291eb7ed 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b382fc 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1529: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000029b3ed3f 13. ./build_docker/./src/Server/HTTPHandler.cpp:529: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000002d0662d1 14. ./build_docker/./src/Server/HTTPHandler.cpp:705: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000002d06d139 15. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000002d1cc337 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 19. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 20. asan_thread_start(void*) @ 0x000000000aa43059 21. ? @ 0x00007f35aab92ac3 22. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:10:45.991192 [ 3000 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:10:46.013344 [ 3035 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:10:46.419976 [ 3064 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:10:46.648169 [ 3043 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:10:46.993031 [ 3115 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:10:47.015465 [ 3143 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:10:47.421861 [ 3113 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:10:47.650099 [ 3135 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:10:47.997359 [ 3198 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:10:48.017436 [ 3231 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:10:48.423897 [ 3235 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:10:48.651951 [ 2774 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:10:49.005618 [ 3205 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:10:49.019460 [ 2800 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:10:49.426044 [ 2843 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:10:49.653838 [ 2863 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:10:50.095054 [ 2873 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:10:50.096596 [ 2946 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:10:50.428006 [ 2867 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:10:50.661564 [ 2918 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:10:51.096785 [ 2967 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:10:51.100711 [ 2967 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:10:51.429650 [ 3032 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:10:51.663522 [ 3024 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:10:52.098643 [ 3112 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:10:52.102524 [ 3093 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:10:52.431683 [ 3126 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:10:52.667791 [ 3214 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:10:53.105098 [ 3157 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:10:53.105841 [ 3195 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:10:53.433534 [ 3228 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:10:53.672084 [ 3235 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:10:54.109915 [ 3065 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:10:54.110232 [ 2761 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:10:54.435162 [ 2788 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:10:54.674486 [ 2819 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:10:55.123415 [ 2900 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:10:55.123751 [ 2899 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:10:55.438200 [ 2866 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:10:55.676583 [ 2936 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:10:56.127055 [ 2856 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:10:56.127862 [ 2915 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:10:56.443546 [ 2986 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:10:56.678630 [ 2974 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:10:57.129050 [ 3000 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:10:57.129820 [ 3006 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:10:57.153218 [ 20881 ] {5146661f-63e1-4179-9441-afa6e70ad09f} executeQuery: Code: 62. DB::Exception: Syntax error: failed at position 32 ('DROP'): DROP COLUMN c. Expected one of: ALTER command, token, OpeningRoundBracket: In scope SELECT formatQuery('ALTER TABLE a (DROP COLUMN b), DROP COLUMN c'). (SYNTAX_ERROR) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:43806) (comment: 02982_unambiguous_alter_commands.sql) (in query: SELECT formatQuery('ALTER TABLE a (DROP COLUMN b), DROP COLUMN c');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::createDeprecated(String const&, int, bool) @ 0x000000000aaee710 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) @ 0x000000002e9e8d35 4. ./build_docker/./src/Parsers/parseQuery.cpp:420: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x000000002e9e8e45 5. DB::(anonymous namespace)::FunctionFormatQuery::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000fdbb82e 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aa8c635 7. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aac91d5 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000cccccfb 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000cccc1ab 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccccc2a 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccce65c 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd2030 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002839a3af 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000028367bce 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028366290 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283b62c9 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002835ae03 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000028359104 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000028357f0d 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002921bdcc 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&) @ 0x000000002941f313 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&) @ 0x0000000029419aef 23. ./contrib/llvm-project/libcxx/include/vector:432: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000029421f5d 24. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000029344c1b 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*) @ 0x0000000029b3703b 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 27. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 28. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 2025.09.09 15:10:57.162896 [ 20881 ] {5146661f-63e1-4179-9441-afa6e70ad09f} TCPHandler: Code: 62. DB::Exception: Syntax error: failed at position 32 ('DROP'): DROP COLUMN c. Expected one of: ALTER command, token, OpeningRoundBracket: In scope SELECT formatQuery('ALTER TABLE a (DROP COLUMN b), DROP COLUMN c'). (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::createDeprecated(String const&, int, bool) @ 0x000000000aaee710 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) @ 0x000000002e9e8d35 4. ./build_docker/./src/Parsers/parseQuery.cpp:420: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x000000002e9e8e45 5. DB::(anonymous namespace)::FunctionFormatQuery::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000fdbb82e 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aa8c635 7. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aac91d5 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000cccccfb 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000cccc1ab 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccccc2a 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccce65c 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd2030 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002839a3af 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000028367bce 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028366290 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283b62c9 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002835ae03 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000028359104 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000028357f0d 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002921bdcc 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&) @ 0x000000002941f313 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&) @ 0x0000000029419aef 23. ./contrib/llvm-project/libcxx/include/vector:432: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000029421f5d 24. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000029344c1b 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*) @ 0x0000000029b3703b 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 27. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 28. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 2025.09.09 15:10:57.214677 [ 20881 ] {82d391a7-c1d6-4826-b3af-272a8ec3f717} executeQuery: Code: 62. DB::Exception: Syntax error: failed at position 30 ('('): (DROP COLUMN c). Expected one of: ALTER command, ADD COLUMN, RENAME COLUMN, MATERIALIZE COLUMN, DROP PARTITION, DROP PART, FORGET PARTITION, DROP DETACHED PARTITION, DROP DETACHED PART, DROP COLUMN, CLEAR COLUMN, ADD INDEX, DROP INDEX, CLEAR INDEX, MATERIALIZE INDEX, ADD STATISTICS, MODIFY STATISTICS, DROP STATISTICS, CLEAR STATISTICS, MATERIALIZE STATISTICS, ADD PROJECTION, DROP PROJECTION, CLEAR PROJECTION, MATERIALIZE PROJECTION, MOVE PART, MOVE PARTITION, ADD CONSTRAINT, DROP CONSTRAINT, DETACH PARTITION, DETACH PART, ATTACH PARTITION, REPLACE PARTITION, ATTACH PART, FETCH PARTITION, FETCH PART, FREEZE, UNFREEZE, MODIFY COLUMN, ALTER COLUMN, MODIFY ORDER BY, MODIFY SAMPLE BY, REMOVE SAMPLE BY, DELETE, UPDATE, COMMENT COLUMN, MODIFY TTL, REMOVE TTL, MATERIALIZE TTL, MODIFY SETTING, RESET SETTING, MODIFY QUERY, MODIFY SQL SECURITY, MODIFY DEFINER, MODIFY REFRESH, MODIFY COMMENT, APPLY DELETED MASK: In scope SELECT formatQuery('ALTER TABLE a DROP COLUMN b, (DROP COLUMN c)'). (SYNTAX_ERROR) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:43806) (comment: 02982_unambiguous_alter_commands.sql) (in query: SELECT formatQuery('ALTER TABLE a DROP COLUMN b, (DROP COLUMN c)');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::createDeprecated(String const&, int, bool) @ 0x000000000aaee710 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) @ 0x000000002e9e8d35 4. ./build_docker/./src/Parsers/parseQuery.cpp:420: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x000000002e9e8e45 5. DB::(anonymous namespace)::FunctionFormatQuery::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000fdbb82e 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aa8c635 7. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aac91d5 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000cccccfb 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000cccc1ab 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccccc2a 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccce65c 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd2030 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002839a3af 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000028367bce 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028366290 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283b62c9 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002835ae03 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000028359104 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000028357f0d 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002921bdcc 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&) @ 0x000000002941f313 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&) @ 0x0000000029419aef 23. ./contrib/llvm-project/libcxx/include/vector:432: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000029421f5d 24. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000029344c1b 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*) @ 0x0000000029b3703b 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 27. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 28. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 2025.09.09 15:10:57.219061 [ 20881 ] {82d391a7-c1d6-4826-b3af-272a8ec3f717} TCPHandler: Code: 62. DB::Exception: Syntax error: failed at position 30 ('('): (DROP COLUMN c). Expected one of: ALTER command, ADD COLUMN, RENAME COLUMN, MATERIALIZE COLUMN, DROP PARTITION, DROP PART, FORGET PARTITION, DROP DETACHED PARTITION, DROP DETACHED PART, DROP COLUMN, CLEAR COLUMN, ADD INDEX, DROP INDEX, CLEAR INDEX, MATERIALIZE INDEX, ADD STATISTICS, MODIFY STATISTICS, DROP STATISTICS, CLEAR STATISTICS, MATERIALIZE STATISTICS, ADD PROJECTION, DROP PROJECTION, CLEAR PROJECTION, MATERIALIZE PROJECTION, MOVE PART, MOVE PARTITION, ADD CONSTRAINT, DROP CONSTRAINT, DETACH PARTITION, DETACH PART, ATTACH PARTITION, REPLACE PARTITION, ATTACH PART, FETCH PARTITION, FETCH PART, FREEZE, UNFREEZE, MODIFY COLUMN, ALTER COLUMN, MODIFY ORDER BY, MODIFY SAMPLE BY, REMOVE SAMPLE BY, DELETE, UPDATE, COMMENT COLUMN, MODIFY TTL, REMOVE TTL, MATERIALIZE TTL, MODIFY SETTING, RESET SETTING, MODIFY QUERY, MODIFY SQL SECURITY, MODIFY DEFINER, MODIFY REFRESH, MODIFY COMMENT, APPLY DELETED MASK: In scope SELECT formatQuery('ALTER TABLE a DROP COLUMN b, (DROP COLUMN c)'). (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::createDeprecated(String const&, int, bool) @ 0x000000000aaee710 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) @ 0x000000002e9e8d35 4. ./build_docker/./src/Parsers/parseQuery.cpp:420: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x000000002e9e8e45 5. DB::(anonymous namespace)::FunctionFormatQuery::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000fdbb82e 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aa8c635 7. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aac91d5 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000cccccfb 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000cccc1ab 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccccc2a 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccce65c 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd2030 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002839a3af 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000028367bce 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028366290 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283b62c9 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002835ae03 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000028359104 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000028357f0d 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002921bdcc 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&) @ 0x000000002941f313 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&) @ 0x0000000029419aef 23. ./contrib/llvm-project/libcxx/include/vector:432: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000029421f5d 24. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000029344c1b 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*) @ 0x0000000029b3703b 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 27. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 28. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 2025.09.09 15:10:57.446056 [ 3063 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:10:57.681538 [ 3048 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:10:58.205068 [ 3115 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:10:58.205780 [ 3088 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:10:58.452494 [ 3176 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:10:58.684606 [ 3193 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:10:59.207170 [ 3202 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:10:59.207807 [ 3227 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:10:59.455104 [ 3212 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:10:59.695833 [ 2790 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:10:59.812108 [ 20881 ] {76c1eb34-84b2-4b13-afd9-68f435cac7a0} executeQuery: Code: 57. DB::Exception: Table test_3.test already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:58316) (comment: 02711_server_uuid_macro.sql) (in query: CREATE TABLE test (`x` UInt8) ENGINE = ReplicatedMergeTree('/clickhouse/tables/{database}/test', 'replica-{server_uuid}') ORDER BY x SETTINGS index_granularity = 62133, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 0.02408456616103649, replace_long_file_name_to_hash = false, max_file_name_length = 0, min_bytes_for_full_part_storage = 238815306, compact_parts_max_bytes_to_buffer = 96563188, compact_parts_max_granules_to_buffer = 256, compact_parts_merge_max_bytes_to_prefetch_part = 22244625, merge_max_block_size = 20942, old_parts_lifetime = 208., 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 = 8803589176, index_granularity_bytes = 5031731, concurrent_part_removal_threshold = 100, allow_vertical_merges_from_compact_to_wide_parts = false, cache_populated_by_fetch = true, marks_compress_block_size = 60014, primary_key_compress_block_size = 87892), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa91e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1558: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291bc5ff 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291ac835 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000291c3415 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b382fc 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 15. asan_thread_start(void*) @ 0x000000000aa43059 16. ? @ 0x00007f35aab92ac3 17. ? @ 0x00007f35aac24850 2025.09.09 15:10:59.813928 [ 20881 ] {76c1eb34-84b2-4b13-afd9-68f435cac7a0} TCPHandler: Code: 57. DB::Exception: Table test_3.test already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa91e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1558: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291bc5ff 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291ac835 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000291c3415 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b382fc 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 15. asan_thread_start(void*) @ 0x000000000aa43059 16. ? @ 0x00007f35aab92ac3 17. ? @ 0x00007f35aac24850 2025.09.09 15:11:00.208958 [ 2777 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:11:00.209575 [ 2771 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:11:00.457081 [ 2804 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:11:00.698466 [ 2865 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:11:01.211523 [ 2849 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:11:01.221514 [ 2891 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:11:01.463013 [ 2906 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:11:01.700697 [ 2936 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:11:02.224210 [ 2930 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:11:02.224779 [ 2963 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:11:02.465361 [ 2903 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:11:02.706384 [ 2979 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:11:03.227023 [ 3012 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:11:03.327636 [ 3029 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:11:03.468885 [ 3048 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:11:03.708687 [ 3101 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:11:04.228826 [ 3144 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:11:04.329210 [ 3155 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:11:04.474620 [ 3189 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:11:04.710650 [ 3216 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:11:05.233076 [ 2749 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:11:05.335795 [ 3224 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:11:05.477501 [ 3160 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:11:05.713021 [ 3190 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:11:06.236059 [ 2776 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:11:06.347763 [ 2777 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:11:06.449388 [ 3722 ] {fb8f53f4-7316-40c7-8868-6658f98e19b4} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=790, jobs=740). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:58480) (comment: 02766_connection_string.sh) (in query: SELECT 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af872f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af7b2d1 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af7c3f3 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d36920d 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000002d369e5f 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processOrdinaryQuery() @ 0x000000002d18af7b 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d17644a 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 15. asan_thread_start(void*) @ 0x000000000aa43059 16. ? @ 0x00007f35aab92ac3 17. ? @ 0x00007f35aac24850 2025.09.09 15:11:06.472311 [ 3722 ] {fb8f53f4-7316-40c7-8868-6658f98e19b4} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=790, jobs=740). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af872f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af7b2d1 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af7c3f3 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d36920d 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000002d369e5f 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processOrdinaryQuery() @ 0x000000002d18af7b 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d17644a 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 15. asan_thread_start(void*) @ 0x000000000aa43059 16. ? @ 0x00007f35aab92ac3 17. ? @ 0x00007f35aac24850 2025.09.09 15:11:06.479835 [ 2781 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:11:06.715734 [ 2843 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:11:07.240639 [ 2891 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:11:07.437664 [ 2866 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:11:07.481811 [ 2951 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:11:07.717857 [ 2932 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:11:08.242716 [ 2871 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:11:08.443065 [ 2981 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:11:08.483919 [ 2988 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:11:08.719863 [ 2982 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:11:09.244610 [ 3017 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:11:09.445734 [ 3045 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:11:09.485945 [ 3073 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:11:09.722452 [ 3040 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:11:10.246465 [ 3162 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:11:10.535990 [ 3113 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:11:10.536310 [ 3183 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:11:10.724633 [ 3188 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:11:11.248580 [ 3173 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:11:11.538599 [ 3240 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:11:11.538864 [ 3184 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:11:11.726626 [ 3235 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:11:12.251152 [ 2739 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:11:12.540384 [ 2820 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:11:12.541001 [ 2811 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:11:12.728865 [ 2819 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:11:13.254647 [ 2906 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:11:13.494687 [ 3722 ] {c0516a60-e157-4f6b-8095-d476b44e6c73} executeQuery: Code: 60. DB::Exception: Unknown table expression identifier 'rmt' in scope SELECT * FROM rmt ORDER BY n ASC. (UNKNOWN_TABLE) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:33062) (comment: 01155_old_mutation_parts_to_do.sh) (in query: select * from rmt order by n;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000c44a97a 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4229: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283b8590 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5417: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002835acd8 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000028359104 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000028357f0d 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002921bdcc 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&) @ 0x000000002941f313 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&) @ 0x0000000029419aef 11. ./contrib/llvm-project/libcxx/include/vector:432: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000029421f5d 12. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000029344c1b 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*) @ 0x0000000029b3703b 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 16. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 20. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 21. asan_thread_start(void*) @ 0x000000000aa43059 22. ? @ 0x00007f35aab92ac3 23. ? @ 0x00007f35aac24850 2025.09.09 15:11:13.498250 [ 3722 ] {c0516a60-e157-4f6b-8095-d476b44e6c73} TCPHandler: Code: 60. DB::Exception: Unknown table expression identifier 'rmt' in scope SELECT * FROM rmt ORDER BY n ASC. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000c44a97a 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4229: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283b8590 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5417: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002835acd8 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000028359104 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000028357f0d 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002921bdcc 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&) @ 0x000000002941f313 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&) @ 0x0000000029419aef 11. ./contrib/llvm-project/libcxx/include/vector:432: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000029421f5d 12. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000029344c1b 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*) @ 0x0000000029b3703b 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 16. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 20. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 21. asan_thread_start(void*) @ 0x000000000aa43059 22. ? @ 0x00007f35aab92ac3 23. ? @ 0x00007f35aac24850 2025.09.09 15:11:13.542440 [ 2953 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:11:13.548935 [ 2890 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:11:13.730959 [ 2898 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:11:14.257961 [ 2957 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:11:14.549915 [ 2980 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:11:14.551474 [ 3008 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:11:14.733426 [ 3011 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:11:14.941800 [ 3722 ] {b3d99a39-ff66-48be-8b39-8aff9dce99a2} executeQuery: Code: 60. DB::Exception: Table test_15.rmt does not exist. Maybe you meant `01070_window_view_watch_events`.mt?. (UNKNOWN_TABLE) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:33082) (comment: 01155_old_mutation_parts_to_do.sh) (in query: drop table rmt;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x000000000ac6a006 4. ./build_docker/./src/Databases/IDatabase.cpp:39: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000027dd1c6a 5. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000286af00b 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:969: DB::DatabaseCatalog::getDatabaseAndTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000286bb62c 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x00000000291eeb31 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x00000000291ed665 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x00000000291ebd68 10. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x00000000291eb7ed 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b382fc 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 14. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 19. asan_thread_start(void*) @ 0x000000000aa43059 20. ? @ 0x00007f35aab92ac3 21. ? @ 0x00007f35aac24850 2025.09.09 15:11:14.946012 [ 3722 ] {b3d99a39-ff66-48be-8b39-8aff9dce99a2} TCPHandler: Code: 60. DB::Exception: Table test_15.rmt does not exist. Maybe you meant `01070_window_view_watch_events`.mt?. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x000000000ac6a006 4. ./build_docker/./src/Databases/IDatabase.cpp:39: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000027dd1c6a 5. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000286af00b 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:969: DB::DatabaseCatalog::getDatabaseAndTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000286bb62c 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x00000000291eeb31 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x00000000291ed665 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x00000000291ebd68 10. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x00000000291eb7ed 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b382fc 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b31685 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d17616c 14. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 19. asan_thread_start(void*) @ 0x000000000aa43059 20. ? @ 0x00007f35aab92ac3 21. ? @ 0x00007f35aac24850 2025.09.09 15:11:15.260695 [ 3028 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:11:15.552191 [ 3027 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:11:15.553306 [ 3070 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:11:15.735894 [ 3094 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:11:16.262608 [ 3108 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:11:16.554218 [ 3125 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:11:16.555308 [ 3189 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:11:16.805094 [ 3196 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:11:17.266735 [ 3197 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:11:17.557698 [ 3241 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:11:17.558137 [ 3168 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:11:17.808419 [ 3229 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:11:18.269246 [ 3243 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:11:18.560216 [ 2776 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:11:18.560593 [ 3205 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:11:18.811289 [ 2820 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:11:19.271840 [ 2828 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:11:19.566143 [ 2891 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:11:19.566430 [ 2901 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:11:19.814587 [ 2822 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:11:20.275037 [ 2841 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:11:20.569087 [ 2930 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:11:20.569145 [ 2929 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:11:20.817952 [ 2837 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:11:21.278277 [ 2979 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:11:21.571709 [ 2974 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:11:21.572319 [ 2924 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:11:21.820372 [ 3000 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:11:22.281624 [ 3027 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:11:22.574729 [ 3093 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:11:22.575928 [ 3096 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:11:22.831581 [ 3084 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:11:23.292420 [ 3182 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:11:23.578078 [ 3204 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:11:23.578518 [ 3158 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:11:23.835030 [ 3172 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:11:24.294626 [ 3202 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:11:24.581886 [ 3220 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:11:24.587782 [ 2745 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:11:24.838574 [ 2744 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:11:25.297583 [ 2787 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:11:25.531701 [ 3722 ] {} ServerErrorHandler: Code: 516. DB::Exception: non_exist_user: Authentication failed: password is incorrect, or there is no user with such name. (AUTHENTICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./build_docker/./src/Access/AccessControl.cpp:626: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x0000000026d2c4b8 4. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x0000000029643e12 5. ./src/Access/Credentials.h:54: DB::Session::authenticate(String const&, String const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x0000000029643224 6. ./contrib/llvm-project/libcxx/include/vector:432: DB::TCPHandler::receiveHello() @ 0x000000002d183910 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d1741d8 8. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 12. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 13. asan_thread_start(void*) @ 0x000000000aa43059 14. ? @ 0x00007f35aab92ac3 15. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:11:25.585945 [ 2800 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:11:25.590156 [ 2766 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:11:25.841657 [ 2810 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:11:25.911003 [ 3722 ] {} ServerErrorHandler: Code: 516. DB::Exception: default: Authentication failed: password is incorrect, or there is no user with such name. If you have installed ClickHouse and forgot password you can reset it in the configuration file. The password for default user is typically located at /etc/clickhouse-server/users.d/default-password.xml and deleting this file will reset the password. See also /etc/clickhouse-server/users.xml on the server where ClickHouse is installed. . (AUTHENTICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./build_docker/./src/Access/AccessControl.cpp:626: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x0000000026d2c4b8 4. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x0000000029643e12 5. ./src/Access/Credentials.h:54: DB::Session::authenticate(String const&, String const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x0000000029643224 6. ./contrib/llvm-project/libcxx/include/vector:432: DB::TCPHandler::receiveHello() @ 0x000000002d183910 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d1741d8 8. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 12. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 13. asan_thread_start(void*) @ 0x000000000aa43059 14. ? @ 0x00007f35aab92ac3 15. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:11:26.300592 [ 2857 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:11:26.589014 [ 2878 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:11:26.597983 [ 2866 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:11:26.844853 [ 2823 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:11:27.257172 [ 2890 ] {} test_3.part_log_profile_events_r2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.09.09 15:11:27.260132 [ 2933 ] {} test_3.part_header_r2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.09.09 15:11:27.261936 [ 2931 ] {} test_3.part_header_r1 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.09.09 15:11:27.263581 [ 2789 ] {} test_3.part_header_r2 (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. ./contrib/llvm-project/libcxx/include/string:1499: _ZN12Coordination9ExceptionC2IRA16_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x000000002e65bfe6 3. ./src/Common/ZooKeeper/IKeeper.h:0: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x000000002e6c2259 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1365: Coordination::ZooKeeper::exists(String const&, std::function, std::shared_ptr>) @ 0x000000002e6c8872 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002e5f1235 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002e5f076a 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:598: zkutil::ZooKeeper::existsWatch(String const&, Coordination::Stat*, std::function) @ 0x000000002e5f16a2 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002e5ebc63 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:203: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x000000002ca16d1a 10. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x000000002ca15340 11. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:50: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x000000002ca13666 12. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 14. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:11:27.266444 [ 2889 ] {} test_3.part_log_profile_events_r1 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.09.09 15:11:27.268182 [ 2911 ] {} test_3.test_03217_merge_replica_2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.09.09 15:11:27.270318 [ 2914 ] {} test_3.src (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.09.09 15:11:27.286458 [ 2902 ] {} test_3.test_03217_merge_replica_1 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.09.09 15:11:27.288383 [ 2869 ] {} test_15.primary_key (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.09.09 15:11:27.291493 [ 2930 ] {} test_1.order_by_all (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.09.09 15:11:27.298469 [ 2926 ] {} test_3.part_header_r1 (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. ./contrib/llvm-project/libcxx/include/string:1499: _ZN12Coordination9ExceptionC2IRA41_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x000000002cb2daa6 3. ./src/Common/ZooKeeper/IKeeper.h:509: _ZN12Coordination9Exception11fromMessageIRA41_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEES0_NS_5ErrorEOS5_ @ 0x000000002e6d1195 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1654: Coordination::ZooKeeper::maybeInjectSendFault() @ 0x000000002e6c26aa 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:0: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x000000002e6c1f3d 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1365: Coordination::ZooKeeper::exists(String const&, std::function, std::shared_ptr>) @ 0x000000002e6c8872 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002e5f1235 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002e5f076a 9. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:598: zkutil::ZooKeeper::existsWatch(String const&, Coordination::Stat*, std::function) @ 0x000000002e5f16a2 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002e5ebc63 11. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:203: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x000000002ca16d1a 12. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x000000002ca15340 13. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:50: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x000000002ca13666 14. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 16. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 19. asan_thread_start(void*) @ 0x000000000aa43059 20. ? @ 0x00007f35aab92ac3 21. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:11:27.303492 [ 2929 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:11:27.591892 [ 2883 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:11:27.600673 [ 2856 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:11:27.847226 [ 2903 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:11:28.306410 [ 3054 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:11:28.594395 [ 3063 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:11:28.603853 [ 3034 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:11:28.850309 [ 3046 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:11:29.311390 [ 3083 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:11:29.597279 [ 3126 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:11:29.606655 [ 3106 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:11:29.853171 [ 3141 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:11:30.313744 [ 3153 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:11:30.599630 [ 3206 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:11:30.608740 [ 2752 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:11:30.855862 [ 3222 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:11:31.315939 [ 2740 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:11:31.601917 [ 2793 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:11:31.611022 [ 2801 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:11:31.858137 [ 2832 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:11:32.318206 [ 2864 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:11:32.604369 [ 2901 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:11:32.613320 [ 2909 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:11:32.860367 [ 2912 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:11:33.327017 [ 2964 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:11:33.606737 [ 2952 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:11:33.615649 [ 2967 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:11:33.863248 [ 2992 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:11:34.331142 [ 2969 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:11:34.609619 [ 2987 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:11:34.618565 [ 2940 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:11:34.866674 [ 3052 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:11:35.340218 [ 3073 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:11:35.612720 [ 3080 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:11:35.627443 [ 3050 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:11:35.869238 [ 3068 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:11:36.342830 [ 3120 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:11:36.615967 [ 3183 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:11:36.630429 [ 3125 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:11:36.871917 [ 3145 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:11:37.344954 [ 3168 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:11:37.617688 [ 2744 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:11:37.639366 [ 3242 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:11:37.874168 [ 2735 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:11:38.347020 [ 2805 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:11:38.619769 [ 2857 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:11:38.642699 [ 2864 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:11:38.945871 [ 2822 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:11:39.348927 [ 2904 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:11:39.621668 [ 2803 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:11:39.644893 [ 2959 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:11:39.947931 [ 2938 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:11:40.351068 [ 2948 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:11:40.623633 [ 3056 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:11:40.646913 [ 3005 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:11:40.949914 [ 3064 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:11:41.353805 [ 3094 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:11:41.626079 [ 3088 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:11:41.649731 [ 3087 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:11:41.957581 [ 3162 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:11:42.357089 [ 3113 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:11:42.628957 [ 3150 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:11:42.655330 [ 3221 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:11:42.966847 [ 3199 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:11:43.359546 [ 3238 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:11:43.631644 [ 2768 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:11:43.657808 [ 3242 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:11:43.968958 [ 3213 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:11:44.361655 [ 2820 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:11:44.633825 [ 2805 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:11:44.659630 [ 2806 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:11:44.971039 [ 2834 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:11:45.363781 [ 2951 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:11:45.635790 [ 2932 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:11:45.661398 [ 2919 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:11:45.973448 [ 2961 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:11:46.365683 [ 2993 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:11:46.638969 [ 2939 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:11:46.664258 [ 2978 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:11:47.058811 [ 2924 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:11:47.368078 [ 3053 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:11:47.641226 [ 3038 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:11:47.666548 [ 3078 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:11:48.061473 [ 3088 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:11:48.371034 [ 3138 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:11:48.644421 [ 3146 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:11:48.669285 [ 3131 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:11:49.064708 [ 3133 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:11:49.374506 [ 3174 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:11:49.647637 [ 3171 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:11:49.675205 [ 3151 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:11:50.068612 [ 3102 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:11:50.376878 [ 3222 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:11:50.650354 [ 2782 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:11:50.677896 [ 2769 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:11:51.070940 [ 2792 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:11:51.383661 [ 2875 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:11:51.652640 [ 2812 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:11:51.679983 [ 2899 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:11:52.073679 [ 2827 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:11:52.386762 [ 2855 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:11:52.655435 [ 2893 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:11:52.683381 [ 2953 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:11:53.076770 [ 2944 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:11:53.392300 [ 3003 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:11:53.659862 [ 2965 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:11:53.686229 [ 2991 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:11:54.079591 [ 3001 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:11:54.395257 [ 3025 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:11:54.662870 [ 3027 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:11:54.688380 [ 3036 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:11:55.082471 [ 3083 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:11:55.399347 [ 3146 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:11:55.667562 [ 3132 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:11:55.695373 [ 3155 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:11:56.084704 [ 3174 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:11:56.403997 [ 3171 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:11:56.670115 [ 3170 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:11:56.697804 [ 2742 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:11:57.086716 [ 3160 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:11:57.406136 [ 2760 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:11:57.673142 [ 2764 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:11:57.701327 [ 2735 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:11:58.089545 [ 2825 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:11:58.441281 [ 2840 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:11:58.675330 [ 2863 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:11:58.703785 [ 2891 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:11:59.091979 [ 2885 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:11:59.443343 [ 2955 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:11:59.677219 [ 2961 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:11:59.705922 [ 2837 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:12:00.094025 [ 2939 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:12:00.455694 [ 2948 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:12:00.679452 [ 3005 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:12:00.707775 [ 3031 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:12:01.096391 [ 3060 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:12:01.458935 [ 3096 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:12:01.709725 [ 3143 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:12:01.760153 [ 3107 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:12:02.098441 [ 3108 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:12:02.461672 [ 3125 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:12:02.712629 [ 3181 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:12:02.796664 [ 3188 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:12:03.100463 [ 3175 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:12:03.472098 [ 2736 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:12:03.720186 [ 3223 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:12:03.798916 [ 2760 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:12:04.168597 [ 2776 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:12:04.474297 [ 2804 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:12:04.722478 [ 2854 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:12:04.809030 [ 2899 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:12:05.170687 [ 2833 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:12:05.476391 [ 2943 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:12:05.724673 [ 2945 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:12:05.811186 [ 2890 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:12:06.172754 [ 2965 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:12:06.479605 [ 2927 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:12:06.726744 [ 3030 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:12:06.813533 [ 3029 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:12:07.174738 [ 3061 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:12:07.481478 [ 3075 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:12:07.728650 [ 3099 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:12:07.815360 [ 3140 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:12:08.176934 [ 3171 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:12:08.488181 [ 3210 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:12:08.730718 [ 3180 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:12:08.820181 [ 3230 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:12:09.179322 [ 3215 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:12:09.490701 [ 2792 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:12:09.732898 [ 2805 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:12:09.822415 [ 2788 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:12:10.187449 [ 2854 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:12:10.493053 [ 2934 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:12:10.734998 [ 2847 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:12:10.824463 [ 2908 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:12:11.189296 [ 2867 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:12:11.495379 [ 2938 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:12:11.736905 [ 2984 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:12:11.882417 [ 3008 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:12:12.191417 [ 3016 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:12:12.497462 [ 3064 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:12:12.738586 [ 3041 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:12:12.884237 [ 3071 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:12:13.193523 [ 3099 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:12:13.499609 [ 3176 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:12:13.740471 [ 3204 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:12:13.886281 [ 3198 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:12:14.197623 [ 3220 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:12:14.514991 [ 3167 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:12:14.742403 [ 2796 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:12:14.888461 [ 2793 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:12:15.199762 [ 2825 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:12:15.517132 [ 2863 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:12:15.744988 [ 2802 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:12:15.890902 [ 2791 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:12:16.201896 [ 2913 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:12:16.519463 [ 2789 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:12:16.747320 [ 2803 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:12:16.893047 [ 2914 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:12:17.203890 [ 2918 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:12:17.521577 [ 2927 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:12:17.749489 [ 3012 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:12:17.895112 [ 3049 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:12:18.206066 [ 3046 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:12:18.523633 [ 3143 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:12:18.751364 [ 3117 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:12:18.897033 [ 3131 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:12:19.207970 [ 3186 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:12:19.526655 [ 3139 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:12:19.753194 [ 2756 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:12:19.899125 [ 2757 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:12:20.210145 [ 2778 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:12:20.528752 [ 2737 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:12:20.754972 [ 2799 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:12:20.901015 [ 2810 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:12:21.212507 [ 2824 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:12:21.530813 [ 2878 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:12:21.757048 [ 2823 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:12:21.902941 [ 2906 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:12:22.214577 [ 2789 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:12:22.532925 [ 2881 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:12:22.759117 [ 3011 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:12:22.904939 [ 2966 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:12:23.216587 [ 2988 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:12:23.535093 [ 3039 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:12:23.761172 [ 3057 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:12:23.907111 [ 3022 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:12:24.227010 [ 3143 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:12:24.537842 [ 3131 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:12:24.764215 [ 3144 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:12:24.909958 [ 3189 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:12:25.229788 [ 3118 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:12:25.540327 [ 3206 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:12:25.766276 [ 3239 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:12:25.912079 [ 2745 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:12:26.232090 [ 2764 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:12:26.542303 [ 2798 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:12:26.768064 [ 2872 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:12:26.913859 [ 2834 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:12:27.233945 [ 2874 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:12:27.544557 [ 2814 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:12:27.770015 [ 2859 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:12:27.932943 [ 2890 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:12:28.236210 [ 2966 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:12:28.547908 [ 2871 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:12:28.772111 [ 3037 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:12:28.935663 [ 3052 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:12:29.238612 [ 3049 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:12:29.550245 [ 3046 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:12:29.774194 [ 3088 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:12:29.937902 [ 3107 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:12:30.240671 [ 3086 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:12:30.552782 [ 3091 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:12:30.776850 [ 3195 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:12:30.940562 [ 3151 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:12:31.242781 [ 3102 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:12:31.555028 [ 2768 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:12:31.779349 [ 3243 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:12:31.942697 [ 2770 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:12:32.244904 [ 2780 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:12:32.557007 [ 2854 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:12:32.781222 [ 2829 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:12:32.944772 [ 2847 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:12:33.247207 [ 2879 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:12:33.559100 [ 2937 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:12:33.804597 [ 2956 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:12:33.946872 [ 2957 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:12:34.252883 [ 2982 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:12:34.562047 [ 2989 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:12:34.811597 [ 2997 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:12:34.948887 [ 3039 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:12:35.262042 [ 3033 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:12:35.565087 [ 3087 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:12:35.813994 [ 3099 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:12:35.950963 [ 3140 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:12:36.266218 [ 3214 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:12:36.569338 [ 3145 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:12:36.817155 [ 3199 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:12:36.954755 [ 3168 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:12:37.269458 [ 2736 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:12:37.572846 [ 3235 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:12:37.849951 [ 2748 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:12:37.985867 [ 2773 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:12:38.272901 [ 3236 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:12:38.576566 [ 2788 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:12:38.853139 [ 2845 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:12:38.989023 [ 2824 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:12:39.275992 [ 2849 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:12:39.579642 [ 2868 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:12:39.856136 [ 2950 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:12:39.992408 [ 2936 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:12:40.279500 [ 2904 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:12:40.581934 [ 2990 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:12:40.858338 [ 2980 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:12:40.995017 [ 2895 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:12:41.282142 [ 2916 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:12:41.584291 [ 3013 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:12:41.860314 [ 3030 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:12:41.997021 [ 3105 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:12:42.284172 [ 3082 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:12:42.586807 [ 3137 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:12:42.862319 [ 3124 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:12:43.024119 [ 3069 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:12:43.286125 [ 3171 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:12:43.588941 [ 3102 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:12:43.864371 [ 3240 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:12:44.026017 [ 2758 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:12:44.288370 [ 2763 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:12:44.641122 [ 3128 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:12:44.866422 [ 2816 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:12:45.028247 [ 2819 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:12:45.290481 [ 2818 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:12:45.644581 [ 2868 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:12:45.869338 [ 2880 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:12:46.035425 [ 2821 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:12:46.293257 [ 2879 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:12:46.647369 [ 2959 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:12:46.872734 [ 2942 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:12:47.037684 [ 3011 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:12:47.296029 [ 2992 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:12:47.650510 [ 2986 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:12:47.875030 [ 3006 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:12:48.040390 [ 3042 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:12:48.299003 [ 3036 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:12:48.654248 [ 3082 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:12:48.877859 [ 3103 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:12:49.042932 [ 3126 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:12:49.301762 [ 3120 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:12:49.656910 [ 3188 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:12:49.881045 [ 3177 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:12:50.046390 [ 3191 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:12:50.304606 [ 2752 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:12:50.660890 [ 3184 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:12:50.884303 [ 2790 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:12:51.050145 [ 2751 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:12:51.307094 [ 2777 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:12:51.663875 [ 2793 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:12:51.887515 [ 2781 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:12:52.053217 [ 2806 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:12:52.310294 [ 2857 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:12:52.666993 [ 2934 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:12:52.890542 [ 2791 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:12:53.056965 [ 2946 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:12:53.313772 [ 2893 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:12:53.670628 [ 2920 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:12:53.972988 [ 2971 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:12:54.060513 [ 2970 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:12:54.345254 [ 2993 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:12:54.674085 [ 2968 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:12:54.980877 [ 3002 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:12:55.063976 [ 2924 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:12:55.348377 [ 3031 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:12:55.677192 [ 3105 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:12:55.984507 [ 3070 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:12:56.066968 [ 3043 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:12:56.351446 [ 3126 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:12:56.680146 [ 3146 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:12:56.987705 [ 3176 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:12:57.069771 [ 3149 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:12:57.356286 [ 3174 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:12:57.584475 [ 3337 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {166e6d4b-ecec-41a4-ad4a-0c1c77ff9a47::202509_322_367_9}: 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, char const*&&) @ 0x000000001adfc17a 4. ./build_docker/./src/Common/MemoryTracker.cpp:187: MemoryTracker::injectFault() const @ 0x000000001adf8d1a 5. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:0: DB::MergePlainMergeTreeTask::finish() @ 0x000000002cc30a65 6. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:0: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000002cc2f47b 7. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000002c427f28 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000002c429675 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7eaf0 10. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001af8a79f 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 13. asan_thread_start(void*) @ 0x000000000aa43059 14. ? @ 0x00007f35aab92ac3 15. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:12:57.683951 [ 3194 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:12:57.992393 [ 3222 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:12:58.072902 [ 2758 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:12:58.359499 [ 3243 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:12:58.687422 [ 2777 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:12:58.994247 [ 2753 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:12:59.075499 [ 3236 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:12:59.362596 [ 2807 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:12:59.689669 [ 2826 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:12:59.996594 [ 2910 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:13:00.078374 [ 2802 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:13:00.365651 [ 2833 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:13:00.692867 [ 2887 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:13:01.010462 [ 2961 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:13:01.081398 [ 2990 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:13:01.368652 [ 2985 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:13:01.696249 [ 2994 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:13:02.012972 [ 2948 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:13:02.084667 [ 3002 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:13:02.371564 [ 2999 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:13:02.699128 [ 3017 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:13:03.016447 [ 3018 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:13:03.090897 [ 3076 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:13:03.373849 [ 3107 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:13:03.702532 [ 3129 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:13:04.018965 [ 3149 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:13:04.093725 [ 3069 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:13:04.376462 [ 3193 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:13:04.705924 [ 3151 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:13:05.022026 [ 3168 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:13:05.097356 [ 3239 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:13:05.379436 [ 2744 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:13:05.709140 [ 2748 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:13:06.025035 [ 2769 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:13:06.107624 [ 2762 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:13:06.382535 [ 2753 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:13:06.712247 [ 2807 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:13:07.028248 [ 2840 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:13:07.109719 [ 2812 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:13:07.385025 [ 2900 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:13:07.714688 [ 2868 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:13:08.030776 [ 2879 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:13:08.111967 [ 2904 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:13:08.484876 [ 2964 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:13:08.718394 [ 2947 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:13:09.033050 [ 2981 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:13:09.114150 [ 2975 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:13:09.486929 [ 2988 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:13:09.725768 [ 3024 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:13:10.035174 [ 3022 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:13:10.116552 [ 3046 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:13:10.489147 [ 3107 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:13:10.728524 [ 3108 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:13:11.037444 [ 3188 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:13:11.118793 [ 3122 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:13:11.493079 [ 3197 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:13:11.731629 [ 3217 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:13:12.039672 [ 3230 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:13:12.120872 [ 2790 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:13:12.495209 [ 3159 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:13:12.748310 [ 2797 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:13:13.042089 [ 2819 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:13:13.123097 [ 2865 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:13:13.497170 [ 2818 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:13:13.751908 [ 2928 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:13:14.045017 [ 2882 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:13:14.126052 [ 2932 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:13:14.499755 [ 2867 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:13:14.755115 [ 2937 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:13:15.047915 [ 2947 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:13:15.137623 [ 2993 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:13:15.504998 [ 2982 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:13:15.758659 [ 3021 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:13:16.051136 [ 2999 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:13:16.209460 [ 3044 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:13:16.508185 [ 3073 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:13:16.762349 [ 3022 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:13:17.054141 [ 3092 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:13:17.212296 [ 3088 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:13:17.511270 [ 3147 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:13:17.766400 [ 3098 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:13:18.056986 [ 3196 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:13:18.266782 [ 3158 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:13:18.514269 [ 2742 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:13:18.769650 [ 3228 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:13:19.060029 [ 3184 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:13:19.272155 [ 3234 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:13:19.517395 [ 2764 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:13:19.772780 [ 2771 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:13:20.063299 [ 2784 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:13:20.275145 [ 2825 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:13:20.521276 [ 2899 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:13:20.529471 [ 3337 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {b2866e3d-697f-407e-a02c-018043ee7457::202509_1_215_97}: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=13, jobs=0). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af80b71 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80746 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002c765aab 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:1197: ? @ 0x000000002c7602b8 8. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x000000002c75fc2b 9. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:0: DB::MergeTreeReaderCompact::MergeTreeReaderCompact(std::shared_ptr, DB::NamesAndTypesList, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*, DB::MarkCache*, DB::MarkRanges, DB::MergeTreeReaderSettings, std::map, std::allocator>>, std::function const&, int) @ 0x000000002c7aee03 10. ./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.h:16: DB::MergeTreeReaderCompactSingleBuffer::MergeTreeReaderCompactSingleBuffer&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int&&) @ 0x000000002c5d6d21 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::MergeTreeDataPartCompact::getReader(DB::NamesAndTypesList const&, std::shared_ptr const&, DB::MarkRanges const&, std::unordered_map, std::equal_to, std::allocator>> const&, DB::UncompressedCache*, DB::MarkCache*, std::shared_ptr const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) const @ 0x000000002c5d1037 12. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:169: DB::MergeTreeSequentialSource::MergeTreeSequentialSource(DB::MergeTreeSequentialSourceType, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::vector>, std::optional, bool, bool, bool) @ 0x000000002c80c330 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:35: DB::MergeTreeSequentialSource* std::construct_at[abi:v15007] const&, std::shared_ptr&, std::shared_ptr&, std::vector>&, std::optional, bool, bool&, bool&, DB::MergeTreeSequentialSource*>(DB::MergeTreeSequentialSource*, DB::MergeTreeSequentialSourceType&, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr&, std::shared_ptr&, std::vector>&, std::optional&&, bool&&, bool&, bool&) @ 0x000000002c81320f 14. ./contrib/llvm-project/libcxx/include/__memory/allocator_traits.h:298: DB::createMergeTreeSequentialSource(DB::MergeTreeSequentialSourceType, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::vector>, std::optional, std::shared_ptr>, bool, bool, bool) @ 0x000000002c810812 15. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1136: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::createMergedStream() @ 0x000000002c3dd079 16. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() @ 0x000000002c3d6516 17. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:534: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x000000002c3e2799 18. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::execute() @ 0x000000002c3ef3fe 19. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:0: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000002cc2f4c0 20. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000002c427f28 21. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000002c429675 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7eaf0 23. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001af8a79f 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 26. asan_thread_start(void*) @ 0x000000000aa43059 27. ? @ 0x00007f35aab92ac3 28. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:13:20.776391 [ 2827 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:13:21.066194 [ 2850 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:13:21.278368 [ 2905 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:13:21.524298 [ 2893 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:13:21.779324 [ 2837 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:13:22.069493 [ 2974 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:13:22.281158 [ 2992 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:13:22.527498 [ 2968 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:13:22.782240 [ 2989 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:13:23.075012 [ 3042 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:13:23.283833 [ 3034 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:13:23.535900 [ 3050 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:13:23.785769 [ 3085 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:13:24.077664 [ 3094 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:13:24.285818 [ 3097 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:13:24.538540 [ 3134 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:13:24.788075 [ 3231 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:13:25.080449 [ 3237 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:13:25.288480 [ 3219 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:13:25.541328 [ 2743 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:13:25.789946 [ 2751 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:13:26.082617 [ 3205 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:13:26.291723 [ 2800 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:13:26.544292 [ 2806 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:13:26.792795 [ 2876 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:13:27.085209 [ 2878 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:13:27.294054 [ 2951 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:13:27.583931 [ 2905 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:13:27.795810 [ 2884 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:13:28.091583 [ 2998 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:13:28.296810 [ 2871 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:13:28.587028 [ 2911 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:13:28.799230 [ 2987 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:13:29.094454 [ 2996 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:13:29.300136 [ 3030 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:13:29.596200 [ 3047 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:13:29.801430 [ 3018 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:13:30.097605 [ 3101 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:13:30.303121 [ 3115 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:13:30.599422 [ 3098 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:13:30.804093 [ 3179 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:13:31.102227 [ 3122 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:13:31.306251 [ 3221 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:13:31.602746 [ 3168 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:13:31.830657 [ 3229 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:13:32.105205 [ 2748 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:13:32.311026 [ 3215 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:13:32.605458 [ 3164 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:13:32.832996 [ 2820 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:13:33.108830 [ 2843 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:13:33.313619 [ 2842 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:13:33.607666 [ 2877 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:13:33.835610 [ 2791 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:13:34.111857 [ 2873 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:13:34.317860 [ 2861 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:13:34.610499 [ 2837 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:13:34.839191 [ 2920 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:13:35.114792 [ 2945 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:13:35.321558 [ 2930 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:13:35.613840 [ 2895 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:13:35.842803 [ 2976 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:13:36.117974 [ 2940 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:13:36.324407 [ 3035 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:13:36.617089 [ 3034 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:13:36.846918 [ 3027 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:13:37.120806 [ 3112 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:13:37.330066 [ 3126 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:13:37.620284 [ 3214 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:13:37.850088 [ 3125 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:13:38.123689 [ 3139 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:13:38.338593 [ 3216 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:13:38.624960 [ 3154 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:13:38.859223 [ 2778 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:13:39.127004 [ 2763 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:13:39.346296 [ 3234 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:13:39.628692 [ 3226 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:13:39.862662 [ 2797 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:13:40.129563 [ 3128 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:13:40.348656 [ 2832 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:13:40.631211 [ 2872 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:13:40.865424 [ 2812 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:13:41.131551 [ 2897 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:13:41.350829 [ 2823 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:13:41.633338 [ 2861 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:13:41.867449 [ 2926 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:13:42.133411 [ 2947 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:13:42.352897 [ 2980 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:13:42.635451 [ 2986 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:13:42.869521 [ 2987 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:13:43.135416 [ 3031 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:13:43.354736 [ 3048 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:13:43.638624 [ 3061 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:13:43.871763 [ 3107 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:13:44.137705 [ 3146 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:13:44.356570 [ 3188 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:13:44.640753 [ 3204 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:13:44.879325 [ 3233 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:13:45.139473 [ 3224 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:13:45.358429 [ 2778 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:13:45.643014 [ 2751 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:13:45.881420 [ 2764 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:13:46.141575 [ 2732 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:13:46.360329 [ 2807 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:13:46.653159 [ 2826 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:13:46.884232 [ 2896 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:13:47.144397 [ 2934 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:13:47.362966 [ 2874 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:13:47.656334 [ 2950 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:13:47.887815 [ 2867 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:13:48.147496 [ 2956 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:13:48.365911 [ 2914 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:13:48.659634 [ 2986 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:13:48.891308 [ 2960 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:13:49.150511 [ 3001 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:13:49.368894 [ 3035 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:13:49.670223 [ 3029 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:13:49.894735 [ 3020 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:13:50.153712 [ 3070 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:13:50.371625 [ 3112 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:13:50.673263 [ 3106 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:13:50.898221 [ 3120 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:13:51.156505 [ 3086 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:13:51.375223 [ 3091 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:13:51.687022 [ 3221 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:13:51.710256 [ 3335 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {106d09da-5a03-4cbf-a443-a9d7490e42ad::202509_1_186_37}: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=13, jobs=0). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af80b71 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80746 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002c765aab 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:1197: ? @ 0x000000002c7602b8 8. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x000000002c75fc2b 9. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:0: DB::MergeTreeReaderCompact::MergeTreeReaderCompact(std::shared_ptr, DB::NamesAndTypesList, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*, DB::MarkCache*, DB::MarkRanges, DB::MergeTreeReaderSettings, std::map, std::allocator>>, std::function const&, int) @ 0x000000002c7aee03 10. ./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.h:16: DB::MergeTreeReaderCompactSingleBuffer::MergeTreeReaderCompactSingleBuffer&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int&&) @ 0x000000002c5d6d21 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::MergeTreeDataPartCompact::getReader(DB::NamesAndTypesList const&, std::shared_ptr const&, DB::MarkRanges const&, std::unordered_map, std::equal_to, std::allocator>> const&, DB::UncompressedCache*, DB::MarkCache*, std::shared_ptr const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) const @ 0x000000002c5d1037 12. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:169: DB::MergeTreeSequentialSource::MergeTreeSequentialSource(DB::MergeTreeSequentialSourceType, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::vector>, std::optional, bool, bool, bool) @ 0x000000002c80c330 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:35: DB::MergeTreeSequentialSource* std::construct_at[abi:v15007] const&, std::shared_ptr&, std::shared_ptr&, std::vector>&, std::optional, bool, bool&, bool&, DB::MergeTreeSequentialSource*>(DB::MergeTreeSequentialSource*, DB::MergeTreeSequentialSourceType&, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr&, std::shared_ptr&, std::vector>&, std::optional&&, bool&&, bool&, bool&) @ 0x000000002c81320f 14. ./contrib/llvm-project/libcxx/include/__memory/allocator_traits.h:298: DB::createMergeTreeSequentialSource(DB::MergeTreeSequentialSourceType, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::vector>, std::optional, std::shared_ptr>, bool, bool, bool) @ 0x000000002c810812 15. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1136: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::createMergedStream() @ 0x000000002c3dd079 16. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() @ 0x000000002c3d6516 17. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:534: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x000000002c3e2799 18. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::execute() @ 0x000000002c3ef3fe 19. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:0: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000002cc2f4c0 20. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000002c427f28 21. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000002c429675 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7eaf0 23. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001af8a79f 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 26. asan_thread_start(void*) @ 0x000000000aa43059 27. ? @ 0x00007f35aab92ac3 28. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:13:51.901449 [ 3194 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:13:52.158661 [ 3192 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:13:52.378010 [ 3220 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:13:52.689863 [ 3130 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:13:52.904218 [ 3234 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:13:53.161431 [ 2773 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:13:53.402466 [ 2820 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:13:53.692717 [ 2781 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:13:53.914623 [ 2843 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:13:54.164147 [ 2854 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:13:54.405343 [ 2809 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:13:54.695835 [ 2908 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:13:54.916674 [ 2913 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:13:55.165977 [ 2963 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:13:55.412407 [ 2941 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:13:55.699088 [ 3004 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:13:55.919475 [ 2982 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:13:56.173713 [ 2916 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:13:56.414608 [ 3031 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:13:56.702125 [ 3057 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:13:56.960574 [ 3062 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:13:57.271679 [ 3072 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:13:57.417041 [ 3089 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:13:57.705299 [ 3129 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:13:57.964676 [ 3179 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:13:58.275669 [ 3123 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:13:58.419652 [ 3211 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:13:58.519214 [ 3339 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {ccc63915-230c-46e1-a015-6f55b3fb64ee::202509_1_210_56}: Code: 241. DB::Exception: Memory tracker (for thread): fault injected (at specific point). (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, char const*&&) @ 0x000000001adfc17a 4. ./build_docker/./src/Common/MemoryTracker.cpp:187: MemoryTracker::injectFault() const @ 0x000000001adf8d1a 5. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:0: DB::MergePlainMergeTreeTask::finish() @ 0x000000002cc30a65 6. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:0: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000002cc2f47b 7. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000002c427f28 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000002c429675 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7eaf0 10. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001af8a79f 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 13. asan_thread_start(void*) @ 0x000000000aa43059 14. ? @ 0x00007f35aab92ac3 15. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:13:58.712292 [ 2752 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:13:58.968358 [ 2745 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:13:59.277854 [ 3190 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:13:59.422090 [ 3226 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:13:59.714843 [ 2770 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:13:59.971844 [ 2800 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:14:00.284353 [ 2747 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:14:00.518408 [ 2824 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:14:00.717023 [ 2817 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:14:00.974284 [ 2888 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:14:01.286462 [ 2936 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:14:01.520424 [ 2867 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:14:01.719114 [ 2898 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:14:01.976356 [ 2979 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:14:02.288815 [ 2967 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:14:02.523002 [ 2968 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:14:02.722080 [ 3021 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:14:02.979381 [ 2995 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:14:03.292013 [ 3039 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:14:03.525695 [ 3022 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:14:03.726247 [ 3070 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:14:03.982116 [ 3066 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:14:04.294837 [ 3126 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:14:04.564074 [ 3132 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:14:04.729473 [ 3100 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:14:04.985168 [ 3149 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:14:05.297809 [ 3118 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:14:05.614083 [ 3216 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:14:05.731903 [ 3102 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:14:06.028115 [ 2744 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:14:06.383891 [ 2767 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:14:06.616369 [ 2770 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:14:06.734193 [ 2792 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:14:07.030424 [ 2875 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:14:07.386124 [ 2826 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:14:07.665548 [ 2886 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:14:07.736993 [ 2849 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:14:08.080344 [ 2836 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:14:08.388664 [ 2919 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:14:08.668396 [ 2964 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:14:08.740428 [ 2956 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:14:09.083543 [ 2931 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:14:09.391478 [ 2975 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:14:09.671384 [ 3015 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:14:09.743819 [ 2976 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:14:10.085906 [ 3019 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:14:10.394327 [ 3070 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:14:10.674145 [ 3107 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:14:10.747510 [ 3165 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:14:11.088807 [ 3146 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:14:11.188562 [ 3339 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {b2866e3d-697f-407e-a02c-018043ee7457::202509_1_222_104}: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=13, jobs=0). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af80b71 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80746 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002c765aab 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:1197: ? @ 0x000000002c7602b8 8. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x000000002c75fc2b 9. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:0: DB::MergeTreeReaderCompact::MergeTreeReaderCompact(std::shared_ptr, DB::NamesAndTypesList, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*, DB::MarkCache*, DB::MarkRanges, DB::MergeTreeReaderSettings, std::map, std::allocator>>, std::function const&, int) @ 0x000000002c7aee03 10. ./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.h:16: DB::MergeTreeReaderCompactSingleBuffer::MergeTreeReaderCompactSingleBuffer&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int&&) @ 0x000000002c5d6d21 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::MergeTreeDataPartCompact::getReader(DB::NamesAndTypesList const&, std::shared_ptr const&, DB::MarkRanges const&, std::unordered_map, std::equal_to, std::allocator>> const&, DB::UncompressedCache*, DB::MarkCache*, std::shared_ptr const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) const @ 0x000000002c5d1037 12. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:169: DB::MergeTreeSequentialSource::MergeTreeSequentialSource(DB::MergeTreeSequentialSourceType, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::vector>, std::optional, bool, bool, bool) @ 0x000000002c80c330 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:35: DB::MergeTreeSequentialSource* std::construct_at[abi:v15007] const&, std::shared_ptr&, std::shared_ptr&, std::vector>&, std::optional, bool, bool&, bool&, DB::MergeTreeSequentialSource*>(DB::MergeTreeSequentialSource*, DB::MergeTreeSequentialSourceType&, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr&, std::shared_ptr&, std::vector>&, std::optional&&, bool&&, bool&, bool&) @ 0x000000002c81320f 14. ./contrib/llvm-project/libcxx/include/__memory/allocator_traits.h:298: DB::createMergeTreeSequentialSource(DB::MergeTreeSequentialSourceType, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::vector>, std::optional, std::shared_ptr>, bool, bool, bool) @ 0x000000002c810812 15. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1136: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::createMergedStream() @ 0x000000002c3dd079 16. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() @ 0x000000002c3d6516 17. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:534: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x000000002c3e2799 18. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::execute() @ 0x000000002c3ef3fe 19. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:0: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000002cc2f4c0 20. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000002c427f28 21. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000002c429675 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7eaf0 23. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001af8a79f 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 26. asan_thread_start(void*) @ 0x000000000aa43059 27. ? @ 0x00007f35aab92ac3 28. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:14:11.396803 [ 3125 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:14:11.521064 [ 3722 ] {77bee7b4-266e-4b2a-b059-ffebc2fbe4e6} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=790, jobs=740). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:48894) (in query: SELECT 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af872f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af7b2d1 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af7c3f3 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d36920d 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000002d369e5f 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processOrdinaryQuery() @ 0x000000002d18af7b 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d17644a 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 15. asan_thread_start(void*) @ 0x000000000aa43059 16. ? @ 0x00007f35aab92ac3 17. ? @ 0x00007f35aac24850 2025.09.09 15:14:11.522812 [ 3722 ] {77bee7b4-266e-4b2a-b059-ffebc2fbe4e6} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=790, jobs=740). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af872f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af7b2d1 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af7c3f3 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d36920d 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000002d369e5f 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processOrdinaryQuery() @ 0x000000002d18af7b 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d17644a 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 15. asan_thread_start(void*) @ 0x000000000aa43059 16. ? @ 0x00007f35aab92ac3 17. ? @ 0x00007f35aac24850 2025.09.09 15:14:11.687126 [ 3157 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:14:11.750542 [ 3163 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:14:12.093376 [ 3175 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:14:12.398017 [ 2752 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:14:12.688218 [ 2811 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:14:12.751846 [ 2926 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:14:13.094634 [ 3127 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:14:13.398508 [ 2807 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:14:13.688651 [ 2779 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:14:13.752308 [ 2821 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:14:14.095238 [ 2791 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:14:14.399133 [ 2795 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:14:14.689243 [ 3065 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:14:14.752832 [ 2942 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:14:15.095813 [ 3070 ] {} test_woql9y2m.table_1017_1 (22ab35b6-a0d5-413f-a282-c3e3b52b0685): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:14:15.165346 [ 20417 ] {} 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. ./contrib/llvm-project/libcxx/include/string:1499: _ZN12Coordination9ExceptionC2IRA41_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x000000002cb2daa6 3. ./src/Common/ZooKeeper/IKeeper.h:509: _ZN12Coordination9Exception11fromMessageIRA41_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEES0_NS_5ErrorEOS5_ @ 0x000000002e6d1195 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1660: Coordination::ZooKeeper::maybeInjectRecvFault() @ 0x000000002e6c134a 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:0: Coordination::ZooKeeper::receiveEvent() @ 0x000000002e6bf27c 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:0: Coordination::ZooKeeper::receiveThread() @ 0x000000002e6be17c 7. ./src/Common/ThreadPool.h:312: 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*) @ 0x000000002e6ceaa7 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 10. asan_thread_start(void*) @ 0x000000000aa43059 11. ? @ 0x00007f35aab92ac3 12. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:14:15.165734 [ 3122 ] {} test_3.part_log_profile_events_r2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.09.09 15:14:15.165920 [ 3091 ] {} test_3.part_header_r2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.09.09 15:14:15.166012 [ 3214 ] {} test_3.part_header_r1 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.09.09 15:14:15.166163 [ 3185 ] {} test_3.part_log_profile_events_r1 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.09.09 15:14:15.166257 [ 3181 ] {} test_3.test_03217_merge_replica_2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.09.09 15:14:15.166344 [ 3150 ] {} test_3.src (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.09.09 15:14:15.167080 [ 3124 ] {} test_3.test_03217_merge_replica_1 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.09.09 15:14:15.167169 [ 3187 ] {} test_15.primary_key (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.09.09 15:14:15.167275 [ 3149 ] {} test_1.order_by_all (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.09.09 15:14:15.167682 [ 3079 ] {} test_1.order_by_all (a211317f-15a5-4e41-9466-f0e3dc49fa7b): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_1/test_03210/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x000000002baf689b 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:14:15.167791 [ 3133 ] {} test_3.part_header_r1 (ReplicatedMergeTreeCleanupThread): void DB::ReplicatedMergeTreeCleanupThread::run(): Code: 999. Coordination::Exception: Coordination error: Connection loss, path /clickhouse/tables/00814_replicated_minimalistic_part_header_zookeeper_test_3/test_00814/part_header/s1/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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: Coordination::Exception::Exception(Coordination::Error, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x00000000264863d9 4. ./src/Common/ZooKeeper/IKeeper.h:501: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x00000000264847c3 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:601: zkutil::ZooKeeper::existsWatch(String const&, Coordination::Stat*, std::function) @ 0x000000002e5f1707 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002e5ebc63 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:203: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x000000002ca16d1a 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x000000002ca15340 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:50: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x000000002ca13666 10. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 12. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 15. asan_thread_start(void*) @ 0x000000000aa43059 16. ? @ 0x00007f35aab92ac3 17. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:14:15.168016 [ 3166 ] {} test_3.part_header_r2 (ReplicatedMergeTreeCleanupThread): void DB::ReplicatedMergeTreeCleanupThread::run(): Code: 999. Coordination::Exception: Coordination error: Connection loss, path /clickhouse/tables/00814_replicated_minimalistic_part_header_zookeeper_test_3/test_00814/part_header/s1/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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: Coordination::Exception::Exception(Coordination::Error, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x00000000264863d9 4. ./src/Common/ZooKeeper/IKeeper.h:501: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x00000000264847c3 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:373: zkutil::ZooKeeper::tryGetChildrenWatch(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000002e5ea628 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:346: zkutil::ZooKeeper::tryGetChildren(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr const&, Coordination::ListRequestType) @ 0x000000002e5e9d09 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:514: DB::ReplicatedMergeTreeCleanupThread::getBlocksSortedByTime(String const&, zkutil::ZooKeeper&, std::vector>&, std::map, std::less, std::allocator>>>&) @ 0x000000002ca25d67 8. ./contrib/llvm-project/libcxx/include/vector:553: DB::ReplicatedMergeTreeCleanupThread::clearOldBlocks(String const&, unsigned long, unsigned long, std::map, std::less, std::allocator>>>&) @ 0x000000002ca1d797 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:165: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x000000002ca1548f 10. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:50: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x000000002ca13666 11. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 13. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 16. asan_thread_start(void*) @ 0x000000000aa43059 17. ? @ 0x00007f35aab92ac3 18. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:14:15.168257 [ 3157 ] {} test_1.order_by_all (a211317f-15a5-4e41-9466-f0e3dc49fa7b): 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. ./contrib/llvm-project/libcxx/include/string:1499: _ZN12Coordination9ExceptionC2IRA16_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x000000002e65bfe6 3. ./src/Common/ZooKeeper/IKeeper.h:0: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x000000002e6c2259 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1437: Coordination::ZooKeeper::list(String const&, Coordination::ListRequestType, std::function, std::shared_ptr>) @ 0x000000002e6caac6 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002e5e9637 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:299: zkutil::ZooKeeper::getChildrenImpl(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000002e5e8bfa 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:372: zkutil::ZooKeeper::tryGetChildrenWatch(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000002e5ea588 8. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:57: zkutil::ZooKeeper::getChildrenWatch(String const&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000002e5ea43b 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:914: DB::ReplicatedMergeTreeQueue::updateMutations(std::shared_ptr, std::shared_ptr>) @ 0x000000002ca8268c 10. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3622: DB::StorageReplicatedMergeTree::mutationsUpdatingTask() @ 0x000000002baf70bc 11. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 13. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 16. asan_thread_start(void*) @ 0x000000000aa43059 17. ? @ 0x00007f35aab92ac3 18. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:14:15.399798 [ 3081 ] {} test_woql9y2m.table_1017_2 (e8eb0663-69fb-4bf6-9779-dc768d5d775a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01017_mutations_with_nondeterministic_functions_zookeeper_test_woql9y2m/table_1017/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabb3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba11483 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bafe8f1 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 11. asan_thread_start(void*) @ 0x000000000aa43059 12. ? @ 0x00007f35aab92ac3 13. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:15:15.498471 [ 3722 ] {f2e5a35f-a0ee-4875-ac5e-d5ed39dc6af5} executeQuery: Code: 159. DB::Exception: Timeout exceeded: elapsed 60.066843919 seconds, maximum: 60. (TIMEOUT_EXCEEDED) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:49096) (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, double&&, double&&) @ 0x000000002785801a 4. ./build_docker/./src/QueryPipeline/ExecutionSpeedLimits.cpp:111: DB::ExecutionSpeedLimits::checkTimeLimit(Stopwatch const&, DB::OverflowMode) const @ 0x0000000027856784 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::finalizeExecution() @ 0x000000002d3489b5 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:132: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000002d348340 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*) @ 0x000000002d36bcf7 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 10. asan_thread_start(void*) @ 0x000000000aa43059 11. ? @ 0x00007f35aab92ac3 12. ? @ 0x00007f35aac24850 2025.09.09 15:15:15.498805 [ 3722 ] {f2e5a35f-a0ee-4875-ac5e-d5ed39dc6af5} TCPHandler: Code: 159. DB::Exception: Timeout exceeded: elapsed 60.066843919 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, double&&, double&&) @ 0x000000002785801a 4. ./build_docker/./src/QueryPipeline/ExecutionSpeedLimits.cpp:111: DB::ExecutionSpeedLimits::checkTimeLimit(Stopwatch const&, DB::OverflowMode) const @ 0x0000000027856784 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::finalizeExecution() @ 0x000000002d3489b5 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:132: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000002d348340 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*) @ 0x000000002d36bcf7 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 10. asan_thread_start(void*) @ 0x000000000aa43059 11. ? @ 0x00007f35aab92ac3 12. ? @ 0x00007f35aac24850 2025.09.09 15:15:16.135609 [ 20345 ] {689c20c1-2911-46c3-bd46-b17fa831c477} 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.10505.altinitytest (altinity build)) (from [::1]:41370) (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::ErrnoException::ErrnoException(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String const&) @ 0x0000000027d0c015 4. ./build_docker/./src/Common/atomicRename.cpp:92: DB::renameat2(String const&, String const&, int) @ 0x0000000027d0bc1b 5. ./build_docker/./src/Common/atomicRename.cpp:213: DB::renameNoReplace(String const&, String const&) @ 0x0000000027d0b399 6. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002918eb44 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000291c33d8 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b382fc 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1529: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000029b3ed3f 10. ./build_docker/./src/Server/HTTPHandler.cpp:529: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000002d0662d1 11. ./build_docker/./src/Server/HTTPHandler.cpp:705: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000002d06d139 12. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000002d1cc337 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 2025.09.09 15:15:16.136429 [ 20345 ] {689c20c1-2911-46c3-bd46-b17fa831c477} 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::ErrnoException::ErrnoException(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String const&) @ 0x0000000027d0c015 4. ./build_docker/./src/Common/atomicRename.cpp:92: DB::renameat2(String const&, String const&, int) @ 0x0000000027d0bc1b 5. ./build_docker/./src/Common/atomicRename.cpp:213: DB::renameNoReplace(String const&, String const&) @ 0x0000000027d0b399 6. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002918eb44 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000291c33d8 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b382fc 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1529: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000029b3ed3f 10. ./build_docker/./src/Server/HTTPHandler.cpp:529: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000002d0662d1 11. ./build_docker/./src/Server/HTTPHandler.cpp:705: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000002d06d139 12. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000002d1cc337 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f35aab92ac3 19. ? @ 0x00007f35aac24850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:15:20.699080 [ 2683 ] {} Application: Closed all listening sockets. Waiting for 28 outstanding connections. 2025.09.09 15:15:25.605139 [ 2683 ] {} Application: Closed connections. But 28 remain. Tip: To increase wait time add to config: 60 2025.09.09 15:15:25.605282 [ 2683 ] {} Application: Will shutdown forcefully. 2025.09.09 15:15:27.363073 [ 28976 ] {} Context: Server was built with address sanitizer. It will work slowly. 2025.09.09 15:15:27.376797 [ 28976 ] {} Context: Server logging level is set to 'test' and performance is degraded. This cannot be used in production. 2025.09.09 15:15:27.377641 [ 28976 ] {} Context: Delay accounting is not enabled, OSIOWaitMicroseconds will not be gathered. You can enable it using `echo 1 > /proc/sys/kernel/task_delayacct` or by using sysctl. 2025.09.09 15:15:27.378231 [ 28976 ] {} Context: The setting 'allow_remote_fs_zero_copy_replication' is enabled for MergeTree tables. But the feature of 'zero-copy replication' is under development and is not ready for production. The usage of this feature can lead to data corruption and loss. The setting should be disabled in production. 2025.09.09 15:15:28.293697 [ 28976 ] {} KeeperServer: Got 1000000000000000 value for setting 'reserved_log_items' which is bigger than int32_t max value, lowering value to 2147483647. 2025.09.09 15:15:28.304238 [ 28976 ] {} RaftInstance: invalid election timeout lower bound detected, adjusted to 0 2025.09.09 15:15:28.304303 [ 28976 ] {} RaftInstance: invalid election timeout upper bound detected, adjusted to 0 2025.09.09 15:15:28.355377 [ 29565 ] {} RaftInstance: Election timeout, initiate leader election 2025.09.09 15:15:29.806532 [ 28976 ] {} Context: Table system.session_log is enabled. It's unreliable and may contain garbage. Do not use it for any kind of security monitoring. 2025.09.09 15:15:30.270352 [ 28976 ] {} loadMetadata: Removing temporary file /var/lib/clickhouse/metadata/test.sql.tmp 2025.09.09 15:15:30.499189 [ 28976 ] {} TablesLoader: Tables test_15.dist_01755 depend on default.i, but seems like that does not exist. Will ignore it and try to load existing tables 2025.09.09 15:15:30.499287 [ 28976 ] {} TablesLoader: Tables test_1.dist_01247 depend on default.number, but seems like that does not exist. Will ignore it and try to load existing tables 2025.09.09 15:15:30.842154 [ 28981 ] {50f71a4b-30d9-4a40-98a8-52ef5066c65d} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=740, jobs=707). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:57972) (in query: SELECT 1), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af872f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af7b2d1 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af7c3f3 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d36920d 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000002d369e5f 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processOrdinaryQuery() @ 0x000000002d18af7b 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d17644a 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 15. asan_thread_start(void*) @ 0x000000000aa43059 16. ? @ 0x00007f8a8c1a2ac3 17. ? @ 0x00007f8a8c234850 2025.09.09 15:15:30.842690 [ 28981 ] {50f71a4b-30d9-4a40-98a8-52ef5066c65d} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=740, jobs=707). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af872f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af7b2d1 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af7c3f3 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d36920d 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000002d369e5f 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processOrdinaryQuery() @ 0x000000002d18af7b 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d17644a 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1a9fa0 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x0000000034530bef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x00000000345317d7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x0000000034433eeb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003442e048 15. asan_thread_start(void*) @ 0x000000000aa43059 16. ? @ 0x00007f8a8c1a2ac3 17. ? @ 0x00007f8a8c234850 2025.09.09 15:15:31.610602 [ 29447 ] {} test_3.part_log_profile_events_r1 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.09.09 15:15:31.610712 [ 29449 ] {} test_3.part_log_profile_events_r2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.09.09 15:15:31.610723 [ 29451 ] {} test_woql9y2m.table_1017_2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.09.09 15:15:31.610859 [ 29453 ] {} test_woql9y2m.table_1017_1 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.09.09 15:15:31.611010 [ 29452 ] {} test_3.test_03217_merge_replica_2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.09.09 15:15:31.611051 [ 29456 ] {} test_3.test_03217_merge_replica_1 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.09.09 15:15:31.611122 [ 29457 ] {} test_3.src (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.09.09 15:15:31.611197 [ 29454 ] {} test_3.part_header_r2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.09.09 15:15:31.611252 [ 29458 ] {} test_1.order_by_all (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.09.09 15:15:31.611390 [ 29455 ] {} test_15.primary_key (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.09.09 15:15:31.611612 [ 29459 ] {} test_3.part_header_r1 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.09.09 15:15:31.645354 [ 29460 ] {} test_3.part_header_r1 (badd489f-7d85-4dd7-8882-42d31f43e543): 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. ./contrib/llvm-project/libcxx/include/string:1499: _ZN12Coordination9ExceptionC2IRA16_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x000000002e65bfe6 3. ./src/Common/ZooKeeper/IKeeper.h:0: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x000000002e6c2259 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1383: Coordination::ZooKeeper::get(String const&, std::function, std::shared_ptr>) @ 0x000000002e6c4432 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002e5f2b99 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:610: zkutil::ZooKeeper::getImpl(String const&, String&, Coordination::Stat*, std::shared_ptr>) @ 0x000000002e5f1db5 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:701: zkutil::ZooKeeper::tryGetWatch(String const&, String&, Coordination::Stat*, std::function, Coordination::Error*) @ 0x000000002e5f3a1e 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002e5f34d2 9. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:638: zkutil::ZooKeeper::get(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000002e5f320b 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::ReplicatedMergeTreeQueue::pullLogsToQueue(std::shared_ptr, std::function, DB::ReplicatedMergeTreeQueue::PullLogsReason) @ 0x000000002ca78b7b 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002baf68ec 12. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 14. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 17. asan_thread_start(void*) @ 0x000000000aa43059 18. ? @ 0x00007f8a8c1a2ac3 19. ? @ 0x00007f8a8c234850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:15:31.645640 [ 29461 ] {} test_3.part_header_r1 (badd489f-7d85-4dd7-8882-42d31f43e543): 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. ./contrib/llvm-project/libcxx/include/string:1499: _ZN12Coordination9ExceptionC2IRA16_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x000000002e65bfe6 3. ./src/Common/ZooKeeper/IKeeper.h:0: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x000000002e6c2259 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1437: Coordination::ZooKeeper::list(String const&, Coordination::ListRequestType, std::function, std::shared_ptr>) @ 0x000000002e6caac6 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002e5e9637 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:299: zkutil::ZooKeeper::getChildrenImpl(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000002e5e8bfa 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:372: zkutil::ZooKeeper::tryGetChildrenWatch(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000002e5ea588 8. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:57: zkutil::ZooKeeper::getChildrenWatch(String const&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000002e5ea43b 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:914: DB::ReplicatedMergeTreeQueue::updateMutations(std::shared_ptr, std::shared_ptr>) @ 0x000000002ca8268c 10. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3622: DB::StorageReplicatedMergeTree::mutationsUpdatingTask() @ 0x000000002baf70bc 11. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 13. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 16. asan_thread_start(void*) @ 0x000000000aa43059 17. ? @ 0x00007f8a8c1a2ac3 18. ? @ 0x00007f8a8c234850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:15:31.647925 [ 29450 ] {} test_3.part_header_r2 (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. ./contrib/llvm-project/libcxx/include/string:1499: _ZN12Coordination9ExceptionC2IRA41_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEOS5_NS_5ErrorE @ 0x000000002cb2daa6 3. ./src/Common/ZooKeeper/IKeeper.h:509: _ZN12Coordination9Exception11fromMessageIRA41_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEES0_NS_5ErrorEOS5_ @ 0x000000002e6d1195 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1654: Coordination::ZooKeeper::maybeInjectSendFault() @ 0x000000002e6c26aa 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:0: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x000000002e6c1f3d 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1437: Coordination::ZooKeeper::list(String const&, Coordination::ListRequestType, std::function, std::shared_ptr>) @ 0x000000002e6caac6 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002e5e9637 8. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:299: zkutil::ZooKeeper::getChildrenImpl(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000002e5e8bfa 9. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:372: zkutil::ZooKeeper::tryGetChildrenWatch(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000002e5ea588 10. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:346: zkutil::ZooKeeper::tryGetChildren(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr const&, Coordination::ListRequestType) @ 0x000000002e5e9d09 11. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:514: DB::ReplicatedMergeTreeCleanupThread::getBlocksSortedByTime(String const&, zkutil::ZooKeeper&, std::vector>&, std::map, std::less, std::allocator>>>&) @ 0x000000002ca25d67 12. ./contrib/llvm-project/libcxx/include/vector:553: DB::ReplicatedMergeTreeCleanupThread::clearOldBlocks(String const&, unsigned long, unsigned long, std::map, std::less, std::allocator>>>&) @ 0x000000002ca1d797 13. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:165: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x000000002ca1548f 14. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:50: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x000000002ca13666 15. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 17. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 20. asan_thread_start(void*) @ 0x000000000aa43059 21. ? @ 0x00007f8a8c1a2ac3 22. ? @ 0x00007f8a8c234850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:15:31.656828 [ 29448 ] {} test_3.part_header_r1 (ReplicatedMergeTreeCleanupThread): void DB::ReplicatedMergeTreeCleanupThread::run(): Code: 999. Coordination::Exception: Coordination error: Connection loss, path /clickhouse/tables/00814_replicated_minimalistic_part_header_zookeeper_test_3/test_00814/part_header/s1/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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: Coordination::Exception::Exception(Coordination::Error, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x00000000264863d9 4. ./src/Common/ZooKeeper/IKeeper.h:501: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x00000000264847c3 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:373: zkutil::ZooKeeper::tryGetChildrenWatch(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000002e5ea628 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:346: zkutil::ZooKeeper::tryGetChildren(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr const&, Coordination::ListRequestType) @ 0x000000002e5e9d09 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:514: DB::ReplicatedMergeTreeCleanupThread::getBlocksSortedByTime(String const&, zkutil::ZooKeeper&, std::vector>&, std::map, std::less, std::allocator>>>&) @ 0x000000002ca25d67 8. ./contrib/llvm-project/libcxx/include/vector:553: DB::ReplicatedMergeTreeCleanupThread::clearOldBlocks(String const&, unsigned long, unsigned long, std::map, std::less, std::allocator>>>&) @ 0x000000002ca1d797 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:0: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x000000002ca153d0 10. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:50: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x000000002ca13666 11. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271eb2d0 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f11dd 13. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f2387 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 16. asan_thread_start(void*) @ 0x000000000aa43059 17. ? @ 0x00007f8a8c1a2ac3 18. ? @ 0x00007f8a8c234850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:15:31.860811 [ 28981 ] {f257cc64-151f-4774-9164-c2906a70531e} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=2, jobs=2). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10505.altinitytest (altinity build)) (from [::1]:57982) (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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af80b71 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80746 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d34b5ca 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000002d3486e4 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000002d34827b 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002d36bcf7 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 12. asan_thread_start(void*) @ 0x000000000aa43059 13. ? @ 0x00007f8a8c1a2ac3 14. ? @ 0x00007f8a8c234850 2025.09.09 15:15:31.861280 [ 28981 ] {f257cc64-151f-4774-9164-c2906a70531e} 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af80b71 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80746 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d34b5ca 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000002d3486e4 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000002d34827b 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002d36bcf7 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 12. asan_thread_start(void*) @ 0x000000000aa43059 13. ? @ 0x00007f8a8c1a2ac3 14. ? @ 0x00007f8a8c234850 2025.09.09 15:15:38.186146 [ 29595 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {166e6d4b-ecec-41a4-ad4a-0c1c77ff9a47::202509_322_406_20}: 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) @ 0x0000000034353454 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb0269 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa8e445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b0f7 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af80b71 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80746 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002c765aab 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:1197: ? @ 0x000000002c7602b8 8. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x000000002c75fc2b 9. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:0: DB::MergeTreeReaderCompact::MergeTreeReaderCompact(std::shared_ptr, DB::NamesAndTypesList, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*, DB::MarkCache*, DB::MarkRanges, DB::MergeTreeReaderSettings, std::map, std::allocator>>, std::function const&, int) @ 0x000000002c7aee03 10. ./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.h:16: DB::MergeTreeReaderCompactSingleBuffer::MergeTreeReaderCompactSingleBuffer&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int&&) @ 0x000000002c5d6d21 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::MergeTreeDataPartCompact::getReader(DB::NamesAndTypesList const&, std::shared_ptr const&, DB::MarkRanges const&, std::unordered_map, std::equal_to, std::allocator>> const&, DB::UncompressedCache*, DB::MarkCache*, std::shared_ptr const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) const @ 0x000000002c5d1037 12. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:169: DB::MergeTreeSequentialSource::MergeTreeSequentialSource(DB::MergeTreeSequentialSourceType, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::vector>, std::optional, bool, bool, bool) @ 0x000000002c80c330 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:35: DB::MergeTreeSequentialSource* std::construct_at[abi:v15007] const&, std::shared_ptr&, std::shared_ptr&, std::vector>&, std::optional, bool, bool&, bool&, DB::MergeTreeSequentialSource*>(DB::MergeTreeSequentialSource*, DB::MergeTreeSequentialSourceType&, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr&, std::shared_ptr&, std::vector>&, std::optional&&, bool&&, bool&, bool&) @ 0x000000002c81320f 14. ./contrib/llvm-project/libcxx/include/__memory/allocator_traits.h:298: DB::createMergeTreeSequentialSource(DB::MergeTreeSequentialSourceType, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::vector>, std::optional, std::shared_ptr>, bool, bool, bool) @ 0x000000002c810812 15. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1136: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::createMergedStream() @ 0x000000002c3dd079 16. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() @ 0x000000002c3d6516 17. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:534: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x000000002c3e2799 18. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::execute() @ 0x000000002c3ef3fe 19. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:0: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000002cc2f4c0 20. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000002c427f28 21. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000002c429675 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7eaf0 23. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001af8a79f 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af79c52 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af86055 26. asan_thread_start(void*) @ 0x000000000aa43059 27. ? @ 0x00007f8a8c1a2ac3 28. ? @ 0x00007f8a8c234850 (version 24.8.14.10505.altinitytest (altinity build)) 2025.09.09 15:15:39.994670 [ 29567 ] {} RaftInstance: failed to accept a rpc connection due to error 125, Operation canceled